JBoss hornetq SVN: r12126 - in trunk: tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution and 1 other directory.
by do-not-reply@jboss.org
Author: borges
Date: 2012-02-16 06:39:06 -0500 (Thu, 16 Feb 2012)
New Revision: 12126
Modified:
trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java
Log:
Improve tearDown: close sessionFactories, assert client(Session|Producer)s are closed.
Modified: trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java
===================================================================
--- trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java 2012-02-15 16:40:29 UTC (rev 12125)
+++ trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java 2012-02-16 11:39:06 UTC (rev 12126)
@@ -40,11 +40,6 @@
import java.util.Map;
import java.util.Set;
import java.util.UUID;
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-import java.util.concurrent.Future;
-import java.util.concurrent.TimeUnit;
import java.util.concurrent.atomic.AtomicInteger;
import javax.naming.Context;
@@ -66,9 +61,7 @@
import org.hornetq.api.core.client.ClientSessionFactory;
import org.hornetq.api.core.client.ServerLocator;
import org.hornetq.core.asyncio.impl.AsynchronousFileImpl;
-import org.hornetq.core.client.impl.ClientConsumerInternal;
import org.hornetq.core.client.impl.ClientSessionFactoryImpl;
-import org.hornetq.core.client.impl.ClientSessionInternal;
import org.hornetq.core.client.impl.ServerLocatorImpl;
import org.hornetq.core.config.Configuration;
import org.hornetq.core.config.impl.ConfigurationImpl;
@@ -87,7 +80,6 @@
import org.hornetq.core.postoffice.PostOffice;
import org.hornetq.core.postoffice.QueueBinding;
import org.hornetq.core.postoffice.impl.LocalQueueBinding;
-import org.hornetq.core.protocol.core.Channel;
import org.hornetq.core.remoting.impl.invm.InVMAcceptorFactory;
import org.hornetq.core.remoting.impl.invm.InVMConnectorFactory;
import org.hornetq.core.remoting.impl.invm.InVMRegistry;
@@ -99,6 +91,8 @@
import org.hornetq.core.server.MessageReference;
import org.hornetq.core.server.Queue;
import org.hornetq.core.server.ServerMessage;
+import org.hornetq.core.server.cluster.ClusterConnection;
+import org.hornetq.core.server.cluster.ClusterManager;
import org.hornetq.core.server.impl.ServerMessageImpl;
import org.hornetq.core.transaction.impl.XidImpl;
import org.hornetq.utils.UUIDGenerator;
@@ -141,7 +135,7 @@
private final Collection<ClientSessionFactory> sessionFactories = new ArrayList<ClientSessionFactory>();
private final Collection<ClientSession> clientSessions = new HashSet<ClientSession>();
private final Collection<ClientConsumer> clientConsumers = new HashSet<ClientConsumer>();
- private final ExecutorService executorService = Executors.newSingleThreadExecutor();
+ private final Collection<HornetQComponent> otherComponents = new HashSet<HornetQComponent>();
private boolean checkThread = true;
@@ -946,22 +940,42 @@
@Override
protected void tearDown() throws Exception
{
- closeAllClientSessions();
-
closeAllSessionFactories();
-
closeAllServerLocatorsFactories();
+ assertAllClientConsumersAreClosed();
+ assertAllClientSessionsAreClosed();
+
synchronized (servers)
{
for (HornetQServer server : servers)
{
+ if (server == null)
+ continue;
+ try
+ {
+ final ClusterManager clusterManager = server.getClusterManager();
+ if (clusterManager != null)
+ {
+ for (ClusterConnection cc : clusterManager.getClusterConnections())
+ {
+ stopComponent(cc);
+ }
+ }
+ }
+ catch (Exception e)
+ {
+ // no-op
+ }
stopComponent(server);
}
servers.clear();
}
- List<ClientSessionFactoryImpl.CloseRunnable> closeRunnables = new ArrayList<ClientSessionFactoryImpl.CloseRunnable>(ClientSessionFactoryImpl.CLOSE_RUNNABLES);
+ closeAllOtherComponents();
+
+ List<ClientSessionFactoryImpl.CloseRunnable> closeRunnables =
+ new ArrayList<ClientSessionFactoryImpl.CloseRunnable>(ClientSessionFactoryImpl.CLOSE_RUNNABLES);
ArrayList<Exception> exceptions = new ArrayList<Exception>();
try
{
@@ -1068,6 +1082,21 @@
}
/**
+ *
+ */
+ private void closeAllOtherComponents()
+ {
+ synchronized (otherComponents)
+ {
+ for (HornetQComponent c : otherComponents)
+ {
+ stopComponent(c);
+ }
+ otherComponents.clear();
+ }
+ }
+
+ /**
* @param buffer
* @return
*/
@@ -1486,140 +1515,99 @@
return sf;
}
- protected HornetQServer addServer(HornetQServer server)
+ protected final HornetQServer addServer(HornetQServer server)
{
- synchronized (servers)
+ if (server != null)
{
- servers.add(server);
+ synchronized (servers)
+ {
+ servers.add(server);
+ }
}
return server;
}
protected final ServerLocator addServerLocator(ServerLocator locator)
{
- synchronized (locators)
+ if (locator != null)
{
- locators.add(locator);
+ synchronized (locators)
+ {
+ locators.add(locator);
+ }
}
return locator;
}
- protected ClientSession addClientSession(ClientSession session)
+ protected final ClientSession addClientSession(ClientSession session)
{
- synchronized (clientSessions)
+ if (session != null)
{
- clientSessions.add(session);
+ synchronized (clientSessions)
+ {
+ clientSessions.add(session);
+ }
}
return session;
}
- protected ClientConsumer addClientConsumer(ClientConsumer consumer)
+ protected final ClientConsumer addClientConsumer(ClientConsumer consumer)
{
- synchronized (clientConsumers)
+ if (consumer != null)
{
- clientConsumers.add(consumer);
+ synchronized (clientConsumers)
+ {
+ clientConsumers.add(consumer);
+ }
}
return consumer;
}
- protected void addSessionFactory(ClientSessionFactory sf)
+ protected final void addHornetQComponent(HornetQComponent component)
{
- synchronized (sessionFactories)
+ if (component != null)
{
- sessionFactories.add(sf);
+ synchronized (otherComponents)
+ {
+ otherComponents.add(component);
+ }
}
}
- private class TerminateBlockedClientSession implements Runnable
+ protected final void addSessionFactory(ClientSessionFactory sf)
{
- private final Channel channel;
- private final CountDownLatch latch;
-
- public TerminateBlockedClientSession(Channel c, CountDownLatch latch)
+ if (sf != null)
{
- this.channel = c;
- this.latch = latch;
- }
- @Override
- public void run()
- {
- try
+ synchronized (sessionFactories)
{
- if (latch.await(3, TimeUnit.SECONDS))
- return;
- channel.unlock();
- channel.returnBlocking();
+ sessionFactories.add(sf);
}
- catch (InterruptedException e)
- {
- // interruption is ok, and gets ignored.
- }
}
}
- protected final void closeAllClientConsumers()
+ private void assertAllClientConsumersAreClosed()
{
synchronized (clientConsumers)
{
for (ClientConsumer cc : clientConsumers)
{
- if (cc == null || cc.isClosed())
+ if (cc == null )
continue;
- try
- {
- if (cc instanceof ClientConsumerInternal)
- {
- ClientConsumerInternal cci = (ClientConsumerInternal)cc;
- Channel channel = cci.getSession().getChannel();
- final CountDownLatch latch = new CountDownLatch(1);
- final Future<?> future = executorService.submit(new TerminateBlockedClientSession(channel, latch));
- cci.close();
- latch.countDown();
- future.cancel(false);
- }
- else
- {
- cc.close();
- }
- }
- catch (Exception e)
- {
- e.printStackTrace(); // no-op
- }
+ assertTrue(cc.isClosed());
}
clientConsumers.clear();
}
}
- protected void closeAllClientSessions()
+ private void assertAllClientSessionsAreClosed()
{
synchronized (clientSessions)
{
for (final ClientSession cs : clientSessions)
{
- if (cs == null || cs.isClosed())
+ if (cs == null)
continue;
- try
- {
- if (cs instanceof ClientSessionInternal)
- {
- ClientSessionInternal csi = ((ClientSessionInternal)cs);
- Channel channel = csi.getChannel();
- final CountDownLatch latch = new CountDownLatch(1);
- final Future<?> future = executorService.submit(new TerminateBlockedClientSession(channel, latch));
- csi.close();
- latch.countDown();
- future.cancel(false);
- }
- else
- {
- cs.close();
- }
- }
- catch (Exception e)
- {
- e.printStackTrace(); // no-op
- }
+ assertTrue(cs.isClosed());
}
clientSessions.clear();
}
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java 2012-02-15 16:40:29 UTC (rev 12125)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java 2012-02-16 11:39:06 UTC (rev 12126)
@@ -162,55 +162,23 @@
protected void tearDown() throws Exception
{
log.info("#test tearDown");
- // closeAllConsumers();
- for (ConsumerHolder ch : consumers)
- {
- addClientConsumer(ch.consumer);
- addClientSession(ch.session);
- }
- closeAllClientConsumers();
- closeAllClientSessions();
- closeAllSessionFactories();
- closeAllServerLocatorsFactories();
for (int i = 0; i < MAX_SERVERS; i++)
{
- if (servers[i] == null)
- continue;
- try
- {
- final ClusterManager clusterManager = servers[i].getClusterManager();
- if (clusterManager != null)
- {
- for (ClusterConnection cc : clusterManager.getClusterConnections())
- {
- cc.stop();
- }
- }
- }
- catch (Exception e)
- {
- // no-op
- }
- stopServers(i);
+ addHornetQComponent(nodeManagers[i]);
}
- for (int i = 0; i < MAX_SERVERS; i++)
- {
- stopComponent(nodeManagers[i]);
- }
- UnitTestCase.checkFreePort(ClusterTestBase.PORTS);
-
servers = null;
sfs = null;
- consumers = null;
-
consumers = new ConsumerHolder[ClusterTestBase.MAX_CONSUMERS];
nodeManagers = null;
super.tearDown();
+
+ UnitTestCase.checkFreePort(ClusterTestBase.PORTS);
+
}
// Private -------------------------------------------------------------------------------------------------------
12 years, 10 months
JBoss hornetq SVN: r12125 - in trunk: tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution and 1 other directory.
by do-not-reply@jboss.org
Author: borges
Date: 2012-02-15 11:40:29 -0500 (Wed, 15 Feb 2012)
New Revision: 12125
Modified:
trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java
Log:
tearDown: Terminate blocking sends earlier, unblock the channel.
Modified: trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java
===================================================================
--- trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java 2012-02-15 16:39:59 UTC (rev 12124)
+++ trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java 2012-02-15 16:40:29 UTC (rev 12125)
@@ -40,6 +40,11 @@
import java.util.Map;
import java.util.Set;
import java.util.UUID;
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
+import java.util.concurrent.Future;
+import java.util.concurrent.TimeUnit;
import java.util.concurrent.atomic.AtomicInteger;
import javax.naming.Context;
@@ -55,11 +60,13 @@
import org.hornetq.api.core.Message;
import org.hornetq.api.core.SimpleString;
import org.hornetq.api.core.TransportConfiguration;
+import org.hornetq.api.core.client.ClientConsumer;
import org.hornetq.api.core.client.ClientMessage;
import org.hornetq.api.core.client.ClientSession;
import org.hornetq.api.core.client.ClientSessionFactory;
import org.hornetq.api.core.client.ServerLocator;
import org.hornetq.core.asyncio.impl.AsynchronousFileImpl;
+import org.hornetq.core.client.impl.ClientConsumerInternal;
import org.hornetq.core.client.impl.ClientSessionFactoryImpl;
import org.hornetq.core.client.impl.ClientSessionInternal;
import org.hornetq.core.client.impl.ServerLocatorImpl;
@@ -80,6 +87,7 @@
import org.hornetq.core.postoffice.PostOffice;
import org.hornetq.core.postoffice.QueueBinding;
import org.hornetq.core.postoffice.impl.LocalQueueBinding;
+import org.hornetq.core.protocol.core.Channel;
import org.hornetq.core.remoting.impl.invm.InVMAcceptorFactory;
import org.hornetq.core.remoting.impl.invm.InVMConnectorFactory;
import org.hornetq.core.remoting.impl.invm.InVMRegistry;
@@ -131,7 +139,9 @@
private final Collection<HornetQServer> servers = new ArrayList<HornetQServer>();
private final Collection<ServerLocator> locators = new ArrayList<ServerLocator>();
private final Collection<ClientSessionFactory> sessionFactories = new ArrayList<ClientSessionFactory>();
- private final Collection<ClientSession> clientSessions = new ArrayList<ClientSession>();
+ private final Collection<ClientSession> clientSessions = new HashSet<ClientSession>();
+ private final Collection<ClientConsumer> clientConsumers = new HashSet<ClientConsumer>();
+ private final ExecutorService executorService = Executors.newSingleThreadExecutor();
private boolean checkThread = true;
@@ -1503,6 +1513,15 @@
return session;
}
+ protected ClientConsumer addClientConsumer(ClientConsumer consumer)
+ {
+ synchronized (clientConsumers)
+ {
+ clientConsumers.add(consumer);
+ }
+ return consumer;
+ }
+
protected void addSessionFactory(ClientSessionFactory sf)
{
synchronized (sessionFactories)
@@ -1511,19 +1530,86 @@
}
}
+ private class TerminateBlockedClientSession implements Runnable
+ {
+ private final Channel channel;
+ private final CountDownLatch latch;
+
+ public TerminateBlockedClientSession(Channel c, CountDownLatch latch)
+ {
+ this.channel = c;
+ this.latch = latch;
+ }
+ @Override
+ public void run()
+ {
+ try
+ {
+ if (latch.await(3, TimeUnit.SECONDS))
+ return;
+ channel.unlock();
+ channel.returnBlocking();
+ }
+ catch (InterruptedException e)
+ {
+ // interruption is ok, and gets ignored.
+ }
+ }
+ }
+
+ protected final void closeAllClientConsumers()
+ {
+ synchronized (clientConsumers)
+ {
+ for (ClientConsumer cc : clientConsumers)
+ {
+ if (cc == null || cc.isClosed())
+ continue;
+ try
+ {
+ if (cc instanceof ClientConsumerInternal)
+ {
+ ClientConsumerInternal cci = (ClientConsumerInternal)cc;
+ Channel channel = cci.getSession().getChannel();
+ final CountDownLatch latch = new CountDownLatch(1);
+ final Future<?> future = executorService.submit(new TerminateBlockedClientSession(channel, latch));
+ cci.close();
+ latch.countDown();
+ future.cancel(false);
+ }
+ else
+ {
+ cc.close();
+ }
+ }
+ catch (Exception e)
+ {
+ e.printStackTrace(); // no-op
+ }
+ }
+ clientConsumers.clear();
+ }
+ }
+
protected void closeAllClientSessions()
{
synchronized (clientSessions)
{
- for (ClientSession cs : clientSessions)
+ for (final ClientSession cs : clientSessions)
{
- if (cs == null)
+ if (cs == null || cs.isClosed())
continue;
try
{
if (cs instanceof ClientSessionInternal)
{
- ((ClientSessionInternal)cs).cleanUp(false);
+ ClientSessionInternal csi = ((ClientSessionInternal)cs);
+ Channel channel = csi.getChannel();
+ final CountDownLatch latch = new CountDownLatch(1);
+ final Future<?> future = executorService.submit(new TerminateBlockedClientSession(channel, latch));
+ csi.close();
+ latch.countDown();
+ future.cancel(false);
}
else
{
@@ -1532,7 +1618,7 @@
}
catch (Exception e)
{
- // no-op
+ e.printStackTrace(); // no-op
}
}
clientSessions.clear();
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java 2012-02-15 16:39:59 UTC (rev 12124)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java 2012-02-15 16:40:29 UTC (rev 12125)
@@ -162,7 +162,15 @@
protected void tearDown() throws Exception
{
log.info("#test tearDown");
- closeAllConsumers();
+ // closeAllConsumers();
+ for (ConsumerHolder ch : consumers)
+ {
+ addClientConsumer(ch.consumer);
+ addClientSession(ch.session);
+ }
+ closeAllClientConsumers();
+ closeAllClientSessions();
+
closeAllSessionFactories();
closeAllServerLocatorsFactories();
for (int i = 0; i < MAX_SERVERS; i++)
@@ -534,7 +542,7 @@
filterString = ClusterTestBase.FILTER_PROP.toString() + "='" + filterVal + "'";
}
- ClientConsumer consumer = session.createConsumer(queueName, filterString);
+ ClientConsumer consumer = addClientConsumer(session.createConsumer(queueName, filterString));
session.start();
12 years, 10 months
JBoss hornetq SVN: r12124 - in trunk: tests/integration-tests/src/test/java/org/hornetq/tests/integration/client and 3 other directories.
by do-not-reply@jboss.org
Author: borges
Date: 2012-02-15 11:39:59 -0500 (Wed, 15 Feb 2012)
New Revision: 12124
Modified:
trunk/hornetq-core/src/test/java/org/hornetq/tests/util/ServiceTestBase.java
trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/ConsumerRoundRobinTest.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessageGroupingConnectionFactoryTest.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessageGroupingTest.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessagePriorityTest.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/NewDeadLetterAddressTest.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/bridge/BridgeTestBase.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/jms/HornetQConnectionFactoryTest.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/jms/connection/ExceptionListenerTest.java
Log:
improve tearDown
Modified: trunk/hornetq-core/src/test/java/org/hornetq/tests/util/ServiceTestBase.java
===================================================================
--- trunk/hornetq-core/src/test/java/org/hornetq/tests/util/ServiceTestBase.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/hornetq-core/src/test/java/org/hornetq/tests/util/ServiceTestBase.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -15,8 +15,6 @@
import java.io.File;
import java.lang.management.ManagementFactory;
-import java.util.ArrayList;
-import java.util.Collection;
import java.util.HashMap;
import java.util.Map;
import java.util.Set;
@@ -35,7 +33,6 @@
import org.hornetq.api.core.client.ClientSessionFactory;
import org.hornetq.api.core.client.HornetQClient;
import org.hornetq.api.core.client.ServerLocator;
-import org.hornetq.core.client.impl.ClientSessionInternal;
import org.hornetq.core.client.impl.Topology;
import org.hornetq.core.config.Configuration;
import org.hornetq.core.logging.Logger;
@@ -82,18 +79,9 @@
protected static final String NETTY_CONNECTOR_FACTORY = NettyConnectorFactory.class.getCanonicalName();
- private final Collection<ClientSessionFactory> sessionFactories = new ArrayList<ClientSessionFactory>();
- private final Collection<ClientSession> clientSessions = new ArrayList<ClientSession>();
-
@Override
protected void tearDown() throws Exception
{
- closeAllClientSessions();
-
- closeAllSessionFactories();
-
- closeAllServerLocatorsFactories();
-
super.tearDown();
if (InVMRegistry.instance.size() > 0)
{
@@ -101,51 +89,7 @@
}
}
- /**
- *
- */
- protected void closeAllSessionFactories()
- {
- synchronized (sessionFactories)
- {
- for (ClientSessionFactory sf : sessionFactories)
- {
- closeSessionFactory(sf);
- }
- sessionFactories.clear();
- }
- }
- /**
- *
- */
- protected void closeAllClientSessions()
- {
- synchronized (clientSessions)
- {
- for (ClientSession cs : clientSessions)
- {
- if (cs == null)
- continue;
- try
- {
- if (cs instanceof ClientSessionInternal)
- {
- ((ClientSessionInternal)cs).cleanUp(false);
- }
- else
- {
- cs.close();
- }
- }
- catch (Exception e)
- {
- // no-op
- }
- }
- clientSessions.clear();
- }
- }
protected void waitForTopology(final HornetQServer server, final int nodes) throws Exception
{
@@ -376,22 +320,6 @@
}
}
- protected ClientSession addClientSession(ClientSession session)
- {
- synchronized (clientSessions)
- {
- clientSessions.add(session);
- }
- return session;
- }
-
- protected void addSessionFactory(ClientSessionFactory sf)
- {
- synchronized (sessionFactories)
- {
- sessionFactories.add(sf);
- }
- }
protected HornetQServer createServer(final boolean realFiles,
final Configuration configuration,
final int pageSize,
@@ -661,13 +589,6 @@
}
}
- protected final ClientSessionFactory createSessionFactory(ServerLocator locator) throws Exception
- {
- ClientSessionFactory sf = locator.createSessionFactory();
- addSessionFactory(sf);
- return sf;
- }
-
protected void createQueue(final String address, final String queue) throws Exception
{
ServerLocator locator = createInVMNonHALocator();
Modified: trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java
===================================================================
--- trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/hornetq-core/src/test/java/org/hornetq/tests/util/UnitTestCase.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -61,6 +61,7 @@
import org.hornetq.api.core.client.ServerLocator;
import org.hornetq.core.asyncio.impl.AsynchronousFileImpl;
import org.hornetq.core.client.impl.ClientSessionFactoryImpl;
+import org.hornetq.core.client.impl.ClientSessionInternal;
import org.hornetq.core.client.impl.ServerLocatorImpl;
import org.hornetq.core.config.Configuration;
import org.hornetq.core.config.impl.ConfigurationImpl;
@@ -117,7 +118,7 @@
public static final String NETTY_CONNECTOR_FACTORY = NettyConnectorFactory.class.getCanonicalName();
protected static final String CLUSTER_PASSWORD = "UnitTestsClusterPassword";
-
+
private static final String OS_TYPE = System.getProperty("os.name").toLowerCase();
// Attributes ----------------------------------------------------
@@ -129,6 +130,8 @@
private final Collection<HornetQServer> servers = new ArrayList<HornetQServer>();
private final Collection<ServerLocator> locators = new ArrayList<ServerLocator>();
+ private final Collection<ClientSessionFactory> sessionFactories = new ArrayList<ClientSessionFactory>();
+ private final Collection<ClientSession> clientSessions = new ArrayList<ClientSession>();
private boolean checkThread = true;
@@ -933,7 +936,12 @@
@Override
protected void tearDown() throws Exception
{
+ closeAllClientSessions();
+ closeAllSessionFactories();
+
+ closeAllServerLocatorsFactories();
+
synchronized (servers)
{
for (HornetQServer server : servers)
@@ -1446,14 +1454,6 @@
}
- protected HornetQServer addServer(HornetQServer server)
- {
- synchronized (servers)
- {
- servers.add(server);
- }
- return server;
- }
protected static final void stopComponent(HornetQComponent component)
{
if (component == null)
@@ -1469,6 +1469,22 @@
}
}
+ protected final ClientSessionFactory createSessionFactory(ServerLocator locator) throws Exception
+ {
+ ClientSessionFactory sf = locator.createSessionFactory();
+ addSessionFactory(sf);
+ return sf;
+ }
+
+ protected HornetQServer addServer(HornetQServer server)
+ {
+ synchronized (servers)
+ {
+ servers.add(server);
+ }
+ return server;
+ }
+
protected final ServerLocator addServerLocator(ServerLocator locator)
{
synchronized (locators)
@@ -1478,6 +1494,63 @@
return locator;
}
+ protected ClientSession addClientSession(ClientSession session)
+ {
+ synchronized (clientSessions)
+ {
+ clientSessions.add(session);
+ }
+ return session;
+ }
+
+ protected void addSessionFactory(ClientSessionFactory sf)
+ {
+ synchronized (sessionFactories)
+ {
+ sessionFactories.add(sf);
+ }
+ }
+
+ protected void closeAllClientSessions()
+ {
+ synchronized (clientSessions)
+ {
+ for (ClientSession cs : clientSessions)
+ {
+ if (cs == null)
+ continue;
+ try
+ {
+ if (cs instanceof ClientSessionInternal)
+ {
+ ((ClientSessionInternal)cs).cleanUp(false);
+ }
+ else
+ {
+ cs.close();
+ }
+ }
+ catch (Exception e)
+ {
+ // no-op
+ }
+ }
+ clientSessions.clear();
+ }
+ }
+
+ protected void closeAllSessionFactories()
+ {
+ synchronized (sessionFactories)
+ {
+ for (ClientSessionFactory sf : sessionFactories)
+ {
+ closeSessionFactory(sf);
+ }
+ sessionFactories.clear();
+ }
+ }
+
protected void closeAllServerLocatorsFactories()
{
synchronized (locators)
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/ConsumerRoundRobinTest.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/ConsumerRoundRobinTest.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/ConsumerRoundRobinTest.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -15,7 +15,12 @@
import junit.framework.Assert;
import org.hornetq.api.core.SimpleString;
-import org.hornetq.api.core.client.*;
+import org.hornetq.api.core.client.ClientConsumer;
+import org.hornetq.api.core.client.ClientMessage;
+import org.hornetq.api.core.client.ClientProducer;
+import org.hornetq.api.core.client.ClientSession;
+import org.hornetq.api.core.client.ClientSessionFactory;
+import org.hornetq.api.core.client.ServerLocator;
import org.hornetq.core.logging.Logger;
import org.hornetq.core.server.HornetQServer;
import org.hornetq.tests.util.ServiceTestBase;
@@ -34,12 +39,10 @@
public void testConsumersRoundRobinCorrectly() throws Exception
{
HornetQServer server = createServer(false);
- try
- {
- server.start();
+ server.start();
ServerLocator locator = createInVMNonHALocator();
- ClientSessionFactory cf = locator.createSessionFactory();
- ClientSession session = cf.createSession(false, true, true);
+ ClientSessionFactory cf = createSessionFactory(locator);
+ ClientSession session = addClientSession(cf.createSession(false, true, true));
session.createQueue(addressA, queueA, false);
ClientConsumer[] consumers = new ClientConsumer[5];
@@ -74,16 +77,6 @@
cm.acknowledge();
}
}
- log.info("closing session");
- session.close();
- }
- finally
- {
- if (server.isStarted())
- {
- server.stop();
- }
- }
}
}
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessageGroupingConnectionFactoryTest.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessageGroupingConnectionFactoryTest.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessageGroupingConnectionFactoryTest.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -112,37 +112,6 @@
}
@Override
- protected void tearDown() throws Exception
- {
- if (clientSession != null)
- {
- try
- {
- clientSession.close();
- }
- catch (HornetQException e1)
- {
- //
- }
- }
- if (server != null && server.isStarted())
- {
- try
- {
- server.stop();
- }
- catch (Exception e1)
- {
- //
- }
- }
- server = null;
- clientSession = null;
-
- super.tearDown();
- }
-
- @Override
protected void setUp() throws Exception
{
super.setUp();
@@ -151,17 +120,19 @@
configuration.setSecurityEnabled(false);
TransportConfiguration transportConfig = new TransportConfiguration(UnitTestCase.INVM_ACCEPTOR_FACTORY);
configuration.getAcceptorConfigurations().add(transportConfig);
- server = HornetQServers.newHornetQServer(configuration, false);
+ server = addServer(HornetQServers.newHornetQServer(configuration, false));
// start the server
server.start();
// then we create a client as normal
- ServerLocator locator = HornetQClient.createServerLocatorWithoutHA(new TransportConfiguration(ServiceTestBase.INVM_CONNECTOR_FACTORY));
+ ServerLocator locator =
+ addServerLocator(HornetQClient.createServerLocatorWithoutHA(new TransportConfiguration(
+ ServiceTestBase.INVM_CONNECTOR_FACTORY)));
locator.setGroupID("grp1");
ClientSessionFactory sessionFactory = locator.createSessionFactory();
- clientSession = sessionFactory.createSession(false, true, true);
+ clientSession = addClientSession(sessionFactory.createSession(false, true, true));
clientSession.createQueue(qName, qName, null, false);
}
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessageGroupingTest.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessageGroupingTest.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessageGroupingTest.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -536,38 +536,6 @@
}
@Override
- protected void tearDown() throws Exception
- {
- if (clientSession != null)
- {
- try
- {
- clientSession.close();
- }
- catch (HornetQException e1)
- {
- //
- }
- }
- if (server != null && server.isStarted())
- {
- try
- {
- server.stop();
- }
- catch (Exception e1)
- {
- //
- }
- }
- locator.close();
- server = null;
- clientSession = null;
-
- super.tearDown();
- }
-
- @Override
protected void setUp() throws Exception
{
super.setUp();
@@ -576,14 +544,16 @@
configuration.setSecurityEnabled(false);
TransportConfiguration transportConfig = new TransportConfiguration(UnitTestCase.INVM_ACCEPTOR_FACTORY);
configuration.getAcceptorConfigurations().add(transportConfig);
- server = HornetQServers.newHornetQServer(configuration, false);
+ server = addServer(HornetQServers.newHornetQServer(configuration, false));
// start the server
server.start();
// then we create a client as normal
- locator = HornetQClient.createServerLocatorWithoutHA(new TransportConfiguration(UnitTestCase.INVM_CONNECTOR_FACTORY));
+ locator =
+ addServerLocator(HornetQClient.createServerLocatorWithoutHA(new TransportConfiguration(
+ UnitTestCase.INVM_CONNECTOR_FACTORY)));
ClientSessionFactory sessionFactory = locator.createSessionFactory();
- clientSession = sessionFactory.createSession(false, true, true);
+ clientSession = addClientSession(sessionFactory.createSession(false, true, true));
clientSession.createQueue(qName, qName, null, false);
}
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessagePriorityTest.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessagePriorityTest.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/MessagePriorityTest.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -45,7 +45,7 @@
private static final Logger log = Logger.getLogger(MessagePriorityTest.class);
-
+
// Attributes ----------------------------------------------------
private HornetQServer server;
@@ -105,11 +105,11 @@
SimpleString address = RandomUtil.randomSimpleString();
session.createQueue(address, queue, false);
-
+
session.start();
ClientProducer producer = session.createProducer(address);
-
+
ClientConsumer consumer = session.createConsumer(queue);
for (int i = 0; i < 10; i++)
@@ -118,18 +118,18 @@
m.setPriority((byte)i);
producer.send(m);
}
-
+
//Wait for msgs to reach client side
-
+
Thread.sleep(1000);
-
+
// expect to consume message with higher priority first
for (int i = 9; i >= 0; i--)
{
ClientMessage m = consumer.receive(500);
-
+
log.info("received msg " + m.getPriority());
-
+
Assert.assertNotNull(m);
Assert.assertEquals(i, m.getPriority());
}
@@ -205,7 +205,7 @@
session.deleteQueue(queue);
}
-
+
// https://jira.jboss.org/jira/browse/HORNETQ-275
public void testOutOfOrderAcknowledgement() throws Exception
{
@@ -226,7 +226,7 @@
m.setPriority((byte)i);
producer.send(m);
}
-
+
Thread.sleep(500);
// Now we wait a little bit to make sure the messages are in the client side buffer
@@ -243,7 +243,7 @@
m.acknowledge();
consumer.close();
-
+
//Close and try and receive the other ones
consumer = session.createConsumer(queue);
@@ -261,13 +261,13 @@
m.acknowledge();
}
-
+
consumer.close();
session.deleteQueue(queue);
}
-
-
+
+
public void testManyMessages() throws Exception
{
SimpleString queue = RandomUtil.randomSimpleString();
@@ -276,7 +276,7 @@
session.createQueue(address, queue, false);
ClientProducer producer = session.createProducer(address);
-
+
for (int i = 0 ; i < 777; i++)
{
ClientMessage msg = session.createMessage(true);
@@ -284,7 +284,7 @@
msg.putBooleanProperty("fast", false);
producer.send(msg);
}
-
+
for (int i = 0 ; i < 333; i++)
{
ClientMessage msg = session.createMessage(true);
@@ -296,8 +296,8 @@
ClientConsumer consumer = session.createConsumer(queue);
session.start();
-
-
+
+
for (int i = 0 ; i < 333; i++)
{
ClientMessage msg = consumer.receive(5000);
@@ -305,7 +305,7 @@
msg.acknowledge();
assertTrue(msg.getBooleanProperty("fast"));
}
-
+
for (int i = 0 ; i < 777; i++)
{
ClientMessage msg = consumer.receive(5000);
@@ -317,11 +317,11 @@
consumer.close();
session.deleteQueue(queue);
-
+
session.close();
}
-
-
+
+
// Package protected ---------------------------------------------
// Protected -----------------------------------------------------
@@ -334,35 +334,17 @@
Configuration config = createDefaultConfig();
config.getAcceptorConfigurations().add(new TransportConfiguration(InVMAcceptorFactory.class.getCanonicalName()));
config.setSecurityEnabled(false);
- server = HornetQServers.newHornetQServer(config, false);
+ server = addServer(HornetQServers.newHornetQServer(config, false));
server.start();
- locator = HornetQClient.createServerLocatorWithoutHA(new TransportConfiguration(ServiceTestBase.INVM_CONNECTOR_FACTORY));
+ locator =
+ addServerLocator(HornetQClient.createServerLocatorWithoutHA(new TransportConfiguration(
+ ServiceTestBase.INVM_CONNECTOR_FACTORY)));
locator.setBlockOnNonDurableSend(true);
locator.setBlockOnDurableSend(true);
- sf = locator.createSessionFactory();
- session = sf.createSession(false, true, true);
+ sf = createSessionFactory(locator);
+ session = addClientSession(sf.createSession(false, true, true));
}
- @Override
- protected void tearDown() throws Exception
- {
- sf.close();
-
- session.close();
-
- locator.close();
-
- server.stop();
-
- sf = null;
-
- session = null;
-
- server = null;
-
- super.tearDown();
- }
-
// Private -------------------------------------------------------
private static void expectMessage(final byte expectedPriority,
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/NewDeadLetterAddressTest.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/NewDeadLetterAddressTest.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/client/NewDeadLetterAddressTest.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -17,16 +17,21 @@
import org.hornetq.api.core.HornetQException;
import org.hornetq.api.core.SimpleString;
import org.hornetq.api.core.TransportConfiguration;
-import org.hornetq.api.core.client.*;
+import org.hornetq.api.core.client.ClientConsumer;
+import org.hornetq.api.core.client.ClientMessage;
+import org.hornetq.api.core.client.ClientProducer;
+import org.hornetq.api.core.client.ClientSession;
+import org.hornetq.api.core.client.ClientSessionFactory;
+import org.hornetq.api.core.client.HornetQClient;
+import org.hornetq.api.core.client.ServerLocator;
import org.hornetq.core.config.Configuration;
-import org.hornetq.core.config.impl.ConfigurationImpl;
import org.hornetq.core.server.HornetQServer;
import org.hornetq.core.server.HornetQServers;
import org.hornetq.core.settings.impl.AddressSettings;
import org.hornetq.tests.util.UnitTestCase;
/**
- *
+ *
* A NewDeadLetterAddressTest
*
* @author <a href="mailto:tim.fox@jboss.com">Tim Fox</a>
@@ -69,11 +74,13 @@
configuration.setSecurityEnabled(false);
TransportConfiguration transportConfig = new TransportConfiguration(UnitTestCase.INVM_ACCEPTOR_FACTORY);
configuration.getAcceptorConfigurations().add(transportConfig);
- server = HornetQServers.newHornetQServer(configuration, false);
+ server = addServer(HornetQServers.newHornetQServer(configuration, false));
// start the server
server.start();
// then we create a client as normal
- locator = HornetQClient.createServerLocatorWithoutHA(new TransportConfiguration(UnitTestCase.INVM_CONNECTOR_FACTORY));
+ locator =
+ addServerLocator(HornetQClient.createServerLocatorWithoutHA(new TransportConfiguration(
+ UnitTestCase.INVM_CONNECTOR_FACTORY)));
ClientSessionFactory sessionFactory = locator.createSessionFactory();
clientSession = sessionFactory.createSession(false, true, false);
}
@@ -92,19 +99,6 @@
//
}
}
- locator.close();
- if (server != null && server.isStarted())
- {
- try
- {
- server.stop();
- }
- catch (Exception e1)
- {
- //
- }
- }
- server = null;
clientSession = null;
super.tearDown();
}
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/bridge/BridgeTestBase.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/bridge/BridgeTestBase.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/bridge/BridgeTestBase.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -54,25 +54,7 @@
@Override
public void tearDown() throws Exception
{
- for (HornetQServer server : servers)
- {
- try
- {
- if (server.isStarted())
- {
- server.stop();
- }
- }
- catch (Throwable e)
- {
- // System.out -> junit report
- System.out.println("Error while stopping server:");
- e.printStackTrace(System.out);
- }
- }
-
servers = null;
-
InVMConnector.failOnCreateConnection = false;
super.tearDown();
@@ -129,7 +111,7 @@
{
service = new InVMNodeManagerServer(serviceConf, nodeManager);
}
-
+ addServer(service);
servers.add(service);
return service;
@@ -178,7 +160,7 @@
{
service = new InVMNodeManagerServer(serviceConf, nodeManager);
}
-
+ addServer(service);
servers.add(service);
return service;
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/jms/HornetQConnectionFactoryTest.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/jms/HornetQConnectionFactoryTest.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/jms/HornetQConnectionFactoryTest.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -686,21 +686,6 @@
startServer();
}
- @Override
- protected void tearDown() throws Exception
- {
- if (liveService.isStarted())
- {
- liveService.stop();
- }
-
- liveService = null;
-
- liveTC = null;
-
- super.tearDown();
- }
-
private void startServer() throws Exception
{
Configuration liveConf = createBasicConfig();
@@ -735,7 +720,7 @@
bcConfigs1.add(bcConfig1);
liveConf.setBroadcastGroupConfigurations(bcConfigs1);
- liveService = HornetQServers.newHornetQServer(liveConf, false);
+ liveService = addServer(HornetQServers.newHornetQServer(liveConf, false));
liveService.start();
}
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/jms/connection/ExceptionListenerTest.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/jms/connection/ExceptionListenerTest.java 2012-02-15 16:39:22 UTC (rev 12123)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/jms/connection/ExceptionListenerTest.java 2012-02-15 16:39:59 UTC (rev 12124)
@@ -28,7 +28,6 @@
import org.hornetq.api.jms.JMSFactoryType;
import org.hornetq.core.client.impl.ClientSessionInternal;
import org.hornetq.core.config.Configuration;
-import org.hornetq.core.config.impl.ConfigurationImpl;
import org.hornetq.core.server.HornetQServer;
import org.hornetq.core.server.HornetQServers;
import org.hornetq.jms.client.HornetQConnection;
@@ -39,7 +38,7 @@
import org.hornetq.tests.util.UnitTestCase;
/**
- *
+ *
* A ExceptionListenerTest
*
* @author <a href="mailto:tim.fox@jboss.com">Tim Fox</a>
@@ -66,12 +65,12 @@
conf.setJMXManagementEnabled(true);
conf.getAcceptorConfigurations()
.add(new TransportConfiguration("org.hornetq.core.remoting.impl.invm.InVMAcceptorFactory"));
- server = HornetQServers.newHornetQServer(conf, false);
+ server = addServer(HornetQServers.newHornetQServer(conf, false));
jmsServer = new JMSServerManagerImpl(server);
jmsServer.setContext(new NullInitialContext());
jmsServer.start();
jmsServer.createQueue(false, ExceptionListenerTest.Q_NAME, null, true, ExceptionListenerTest.Q_NAME);
- cf = (HornetQConnectionFactory) HornetQJMSClient.createConnectionFactoryWithoutHA(JMSFactoryType.CF, new TransportConfiguration("org.hornetq.core.remoting.impl.invm.InVMConnectorFactory"));
+ cf = HornetQJMSClient.createConnectionFactoryWithoutHA(JMSFactoryType.CF, new TransportConfiguration("org.hornetq.core.remoting.impl.invm.InVMConnectorFactory"));
cf.setBlockOnDurableSend(true);
cf.setPreAcknowledge(true);
}
@@ -81,20 +80,7 @@
{
jmsServer.stop();
cf = null;
- if (server != null && server.isStarted())
- {
- try
- {
- server.stop();
- }
- catch (Exception e)
- {
- e.printStackTrace();
- }
- server = null;
- }
-
server = null;
jmsServer = null;
cf = null;
12 years, 10 months
JBoss hornetq SVN: r12123 - trunk.
by do-not-reply@jboss.org
Author: borges
Date: 2012-02-15 11:39:22 -0500 (Wed, 15 Feb 2012)
New Revision: 12123
Modified:
trunk/pom.xml
Log:
maven: set minimum version to 3.0.0, and update version numbers for some plugins.
Modified: trunk/pom.xml
===================================================================
--- trunk/pom.xml 2012-02-15 16:39:11 UTC (rev 12122)
+++ trunk/pom.xml 2012-02-15 16:39:22 UTC (rev 12123)
@@ -25,6 +25,11 @@
</license>
</licenses>
+
+ <prerequisites>
+ <maven>3.0.0</maven>
+ </prerequisites>
+
<properties>
<netty.version>3.2.3.Final</netty.version>
<netty.version.string>3.2.3.Final</netty.version.string>
@@ -425,7 +430,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-jar-plugin</artifactId>
- <version>2.3.2</version>
+ <version>2.4</version>
</plugin>
<plugin>
<groupId>net.sf.maven-sar</groupId>
@@ -470,7 +475,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-surefire-plugin</artifactId>
- <version>2.11</version>
+ <version>2.12</version>
<configuration>
<forkMode>once</forkMode>
<testFailureIgnore>true</testFailureIgnore>
@@ -482,7 +487,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-surefire-report-plugin</artifactId>
- <version>2.11</version>
+ <version>2.12</version>
</plugin>
<plugin>
<groupId>org.apache.maven.plugins</groupId>
@@ -495,7 +500,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-pmd-plugin</artifactId>
- <version>2.6</version>
+ <version>2.7</version>
<configuration>
<linkXref>true</linkXref>
<sourceEncoding>utf-8</sourceEncoding>
@@ -531,7 +536,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-javadoc-plugin</artifactId>
- <version>2.8</version>
+ <version>2.8.1</version>
</plugin>
<plugin>
<groupId>org.apache.maven.plugins</groupId>
@@ -559,7 +564,7 @@
<plugin>
<groupId>org.codehaus.mojo</groupId>
<artifactId>findbugs-maven-plugin</artifactId>
- <version>2.3.3</version>
+ <version>2.4.0</version>
<configuration>
<excludeFilterFile>${user.dir}/etc/findbugs-exclude.xml</excludeFilterFile>
<findbugsXmlOutput>true</findbugsXmlOutput>
@@ -572,7 +577,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-eclipse-plugin</artifactId>
- <version>2.8</version>
+ <version>2.9</version>
<configuration>
<downloadSources>true</downloadSources>
<downloadJavadocs>true</downloadJavadocs>
@@ -611,7 +616,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-checkstyle-plugin</artifactId>
- <version>2.8</version>
+ <version>2.9</version>
<configuration>
<configLocation>checkstyle.xml</configLocation>
</configuration>
@@ -629,7 +634,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-javadoc-plugin</artifactId>
- <version>2.8</version>
+ <version>2.8.1</version>
<configuration>
<minmemory>128m</minmemory>
<maxmemory>1024m</maxmemory>
@@ -648,7 +653,7 @@
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-surefire-report-plugin</artifactId>
- <version>2.11</version>
+ <version>2.12</version>
</plugin>
</plugins>
</reporting>
12 years, 10 months
JBoss hornetq SVN: r12122 - in trunk: hornetq-core/src/main/java/org/hornetq/core/server/impl and 3 other directories.
by do-not-reply@jboss.org
Author: borges
Date: 2012-02-15 11:39:11 -0500 (Wed, 15 Feb 2012)
New Revision: 12122
Modified:
trunk/hornetq-core/src/main/java/org/hornetq/core/server/HornetQServer.java
trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl/HornetQServerImpl.java
trunk/hornetq-core/src/test/java/org/hornetq/tests/util/ServiceTestBase.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/bridge/BridgeTestBase.java
trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java
Log:
Add a waitForInitialization method to simplify test code.
Modified: trunk/hornetq-core/src/main/java/org/hornetq/core/server/HornetQServer.java
===================================================================
--- trunk/hornetq-core/src/main/java/org/hornetq/core/server/HornetQServer.java 2012-02-15 16:38:34 UTC (rev 12121)
+++ trunk/hornetq-core/src/main/java/org/hornetq/core/server/HornetQServer.java 2012-02-15 16:39:11 UTC (rev 12122)
@@ -15,7 +15,9 @@
import java.util.List;
import java.util.Set;
+import java.util.concurrent.CountDownLatch;
import java.util.concurrent.ScheduledExecutorService;
+import java.util.concurrent.TimeUnit;
import org.hornetq.api.core.HornetQException;
import org.hornetq.api.core.Pair;
@@ -143,6 +145,15 @@
boolean isInitialised();
+ /**
+ * Wait for server initialization.
+ * @param timeout
+ * @param unit
+ * @see CountDownLatch#await(long, TimeUnit)
+ * @throws InterruptedException
+ */
+ boolean waitForInitialization(long timeout, TimeUnit unit) throws InterruptedException;
+
Queue createQueue(SimpleString address,
SimpleString queueName,
SimpleString filter,
Modified: trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl/HornetQServerImpl.java
===================================================================
--- trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl/HornetQServerImpl.java 2012-02-15 16:38:34 UTC (rev 12121)
+++ trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl/HornetQServerImpl.java 2012-02-15 16:39:11 UTC (rev 12122)
@@ -28,6 +28,7 @@
import java.util.Map.Entry;
import java.util.Set;
import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.CountDownLatch;
import java.util.concurrent.ExecutorService;
import java.util.concurrent.Executors;
import java.util.concurrent.ScheduledExecutorService;
@@ -225,8 +226,13 @@
private final Map<String, ServerSession> sessions = new ConcurrentHashMap<String, ServerSession>();
+ /**
+ * We guard the {@code initialised} field because if we restart a {@code HornetQServer}, we need
+ * to replace the {@code CountDownLatch} by a new one.
+ */
private final Object initialiseLock = new Object();
- private boolean initialised;
+ private CountDownLatch initialised = new CountDownLatch(1);
+
private final Object startUpLock = new Object();
private final Object replicationLock = new Object();
@@ -666,7 +672,13 @@
sessions.clear();
started = false;
- initialised = false;
+ synchronized (initialiseLock)
+ {
+ // replace the latch only if necessary. It could still be '1' in case of errors
+ // during start-up.
+ if (initialised.getCount() < 1)
+ initialised = new CountDownLatch(1);
+ }
}
// to display in the log message
@@ -910,14 +922,26 @@
return new HashSet<ServerSession>(sessions.values());
}
+ @Override
public boolean isInitialised()
{
synchronized (initialiseLock)
{
- return initialised;
+ return initialised.getCount() < 1;
}
}
+ @Override
+ public boolean waitForInitialization(long timeout, TimeUnit unit) throws InterruptedException
+ {
+ CountDownLatch latch;
+ synchronized (initialiseLock)
+ {
+ latch = initialised;
+ }
+ return latch.await(timeout, unit);
+ }
+
public HornetQServerControlImpl getHornetQServerControl()
{
return messagingServerControl;
@@ -1482,8 +1506,7 @@
remotingService.start();
- initialised = true;
-
+ initialised.countDown();
}
/**
Modified: trunk/hornetq-core/src/test/java/org/hornetq/tests/util/ServiceTestBase.java
===================================================================
--- trunk/hornetq-core/src/test/java/org/hornetq/tests/util/ServiceTestBase.java 2012-02-15 16:38:34 UTC (rev 12121)
+++ trunk/hornetq-core/src/test/java/org/hornetq/tests/util/ServiceTestBase.java 2012-02-15 16:39:11 UTC (rev 12122)
@@ -20,6 +20,7 @@
import java.util.HashMap;
import java.util.Map;
import java.util.Set;
+import java.util.concurrent.TimeUnit;
import javax.management.MBeanServer;
@@ -331,16 +332,8 @@
if (!server.getConfiguration().isBackup())
{
- timetowait = System.currentTimeMillis() + 5000;
- while (!server.isInitialised() && System.currentTimeMillis() < timetowait)
- {
- Thread.sleep(50);
- }
-
- if (!server.isInitialised())
- {
+ if (!server.waitForInitialization(5000, TimeUnit.MILLISECONDS))
fail("Server didn't initialize: " + server);
- }
}
}
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/bridge/BridgeTestBase.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/bridge/BridgeTestBase.java 2012-02-15 16:38:34 UTC (rev 12121)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/bridge/BridgeTestBase.java 2012-02-15 16:39:11 UTC (rev 12122)
@@ -15,12 +15,12 @@
import java.util.ArrayList;
import java.util.Map;
+import java.util.concurrent.TimeUnit;
import javax.management.MBeanServer;
import org.hornetq.api.core.TransportConfiguration;
import org.hornetq.core.config.Configuration;
-import org.hornetq.core.config.impl.ConfigurationImpl;
import org.hornetq.core.remoting.impl.invm.InVMConnector;
import org.hornetq.core.remoting.impl.netty.NettyAcceptorFactory;
import org.hornetq.core.server.HornetQServer;
@@ -34,7 +34,7 @@
* A BridgeTestBase
*
* @author <a href="mailto:tim.fox@jboss.com">Tim Fox</a>
- *
+ *
* Created 21 Nov 2008 10:32:23
*
*
@@ -187,21 +187,8 @@
protected void waitForServerStart(HornetQServer server) throws Exception
{
- long start = System.currentTimeMillis();
- do
- {
- if (server.isInitialised())
- {
- return;
- }
- Thread.sleep(10);
- }
- while (System.currentTimeMillis() - start < 5000);
-
- String msg = "Timed out waiting for server starting = " + server;
-
-
- throw new IllegalStateException(msg);
+ if (!server.waitForInitialization(5000L, TimeUnit.MILLISECONDS))
+ throw new IllegalStateException("Timed out waiting for server starting = " + server);
}
// Inner classes -------------------------------------------------
Modified: trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java
===================================================================
--- trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java 2012-02-15 16:38:34 UTC (rev 12121)
+++ trunk/tests/integration-tests/src/test/java/org/hornetq/tests/integration/cluster/distribution/ClusterTestBase.java 2012-02-15 16:39:11 UTC (rev 12122)
@@ -24,6 +24,7 @@
import java.util.List;
import java.util.Map;
import java.util.Set;
+import java.util.concurrent.TimeUnit;
import junit.framework.Assert;
@@ -296,21 +297,14 @@
protected void waitForServerRestart(final int node) throws Exception
{
- long start = System.currentTimeMillis();
- do
+ if (!servers[node].waitForInitialization(ServiceTestBase.WAIT_TIMEOUT, TimeUnit.MILLISECONDS))
{
- if (servers[node].isInitialised())
- {
- return;
- }
- Thread.sleep(10);
- }
- while (System.currentTimeMillis() - start < ServiceTestBase.WAIT_TIMEOUT);
- String msg = "Timed out waiting for server starting = " + node;
+ String msg = "Timed out waiting for server starting = " + node;
- log.error(msg);
+ log.error(msg);
- throw new IllegalStateException(msg);
+ throw new IllegalStateException(msg);
+ }
}
protected void waitForBindings(final int node,
@@ -1865,7 +1859,7 @@
serverFrom.getConfiguration().getConnectorConfigurations().put(serverTotc.getName(), serverTotc);
pairs.add(serverTotc.getName());
}
-
+
ClusterConnectionConfiguration clusterConf = new ClusterConnectionConfiguration(
name, address, connectorFrom.getName(),
HornetQClient.DEFAULT_MIN_LARGE_MESSAGE_SIZE,
12 years, 10 months
JBoss hornetq SVN: r12121 - trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl.
by do-not-reply@jboss.org
Author: borges
Date: 2012-02-15 11:38:34 -0500 (Wed, 15 Feb 2012)
New Revision: 12121
Modified:
trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl/ConnectorsService.java
Log:
Document class' purpose at Javadoc.
Modified: trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl/ConnectorsService.java
===================================================================
--- trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl/ConnectorsService.java 2012-02-15 16:38:20 UTC (rev 12120)
+++ trunk/hornetq-core/src/main/java/org/hornetq/core/server/impl/ConnectorsService.java 2012-02-15 16:38:34 UTC (rev 12121)
@@ -12,6 +12,11 @@
*/
package org.hornetq.core.server.impl;
+import java.util.HashSet;
+import java.util.List;
+import java.util.Set;
+import java.util.concurrent.ScheduledExecutorService;
+
import org.hornetq.core.config.Configuration;
import org.hornetq.core.config.ConnectorServiceConfiguration;
import org.hornetq.core.logging.Logger;
@@ -22,14 +27,13 @@
import org.hornetq.core.server.HornetQComponent;
import org.hornetq.utils.ConfigurationHelper;
-import java.util.HashSet;
-import java.util.List;
-import java.util.Set;
-import java.util.concurrent.ScheduledExecutorService;
-
/**
- * @author <a href="mailto:andy.taylor@jboss.org">Andy Taylor</a>
- * Created Jun 29, 2010
+ * ConnectorsService will pool some resource for updates, e.g. Twitter, then the changes are picked
+ * and converted into a ServerMessage for a given destination (queue).
+ * <p>
+ * It may also listen to a queue, and forward them (e.g. messages arriving at the queue are picked
+ * and tweeted to some Twitter account).
+ * @author <a href="mailto:andy.taylor@jboss.org">Andy Taylor</a> Created Jun 29, 2010
*/
public class ConnectorsService implements HornetQComponent
{
12 years, 10 months
JBoss hornetq SVN: r12120 - trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/core/config/impl.
by do-not-reply@jboss.org
Author: borges
Date: 2012-02-15 11:38:20 -0500 (Wed, 15 Feb 2012)
New Revision: 12120
Modified:
trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/core/config/impl/ConfigurationValidationTest.java
Log:
Restore FIX: Correct the reference path of searched resource.
When using Ant the classpath would be manually modified to include the
"schema" folder. In practice, leaving "schema/" out tests only for the
manual classpath modification.
Modified: trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/core/config/impl/ConfigurationValidationTest.java
===================================================================
--- trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/core/config/impl/ConfigurationValidationTest.java 2012-02-15 15:57:16 UTC (rev 12119)
+++ trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/core/config/impl/ConfigurationValidationTest.java 2012-02-15 16:38:20 UTC (rev 12120)
@@ -51,7 +51,7 @@
String xml = "<configuration xmlns='urn:hornetq'>" + "</configuration>";
Element element = XMLUtil.stringToElement(xml);
Assert.assertNotNull(element);
- XMLUtil.validate(element, "hornetq-configuration.xsd");
+ XMLUtil.validate(element, "schema/hornetq-configuration.xsd");
}
public void testFullConfiguration() throws Exception
12 years, 10 months
JBoss hornetq SVN: r12118 - trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/ra.
by do-not-reply@jboss.org
Author: gaohoward
Date: 2012-02-15 08:43:40 -0500 (Wed, 15 Feb 2012)
New Revision: 12118
Modified:
trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/ra/HornetQResourceAdapterConfigTest.java
Log:
fix test failure
Modified: trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/ra/HornetQResourceAdapterConfigTest.java
===================================================================
--- trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/ra/HornetQResourceAdapterConfigTest.java 2012-02-15 11:53:02 UTC (rev 12117)
+++ trunk/tests/unit-tests/src/test/java/org/hornetq/tests/unit/ra/HornetQResourceAdapterConfigTest.java 2012-02-15 13:43:40 UTC (rev 12118)
@@ -296,6 +296,12 @@
" <config-property-name>SetupAttempts</config-property-name>\n" +
" <config-property-type>int</config-property-type>\n" +
" <config-property-value></config-property-value>\n" +
+ " </config-property>"+
+ " <config-property>\n" +
+ " <description>Add a new managed connection factory</description>\n" +
+ " <config-property-name>ManagedConnectionFactory</config-property-name>\n" +
+ " <config-property-type>org.hornetq.ra.HornetQRAManagedConnectionFactory</config-property-type>\n" +
+ " <config-property-value></config-property-value>\n" +
" </config-property>";
12 years, 10 months
JBoss hornetq SVN: r12117 - trunk.
by do-not-reply@jboss.org
Author: ataylor
Date: 2012-02-15 06:53:02 -0500 (Wed, 15 Feb 2012)
New Revision: 12117
Modified:
trunk/.gitignore
Log:
added ignored intellij files
Modified: trunk/.gitignore
===================================================================
--- trunk/.gitignore 2012-02-15 11:42:44 UTC (rev 12116)
+++ trunk/.gitignore 2012-02-15 11:53:02 UTC (rev 12117)
@@ -1,3 +1,8 @@
+.idea
+*.iml
+*/*.iml
+*/*/*.iml
+*/*/*/*.iml
*~
target
tests/jms-tests/data
12 years, 10 months
JBoss hornetq SVN: r12116 - in trunk: distribution and 34 other directories.
by do-not-reply@jboss.org
Author: ataylor
Date: 2012-02-15 06:42:44 -0500 (Wed, 15 Feb 2012)
New Revision: 12116
Removed:
trunk/distribution/hornetq-distribution.iml
trunk/distribution/hornetq/hornetq (1).iml
trunk/distribution/jnp-client/jnp-client.iml
trunk/docs/hornetq-docs.iml
trunk/docs/quickstart-guide/HornetQ_QuickStart_Guide-en.iml
trunk/docs/rest-manual/HornetQ_Rest_Manual-en.iml
trunk/docs/user-manual/HornetQ_User_Manual-en.iml
trunk/examples/hornetq-examples.iml
trunk/examples/jms/hornetq-jms-examples.iml
trunk/hornetq-bootstrap/hornetq-bootstrap.iml
trunk/hornetq-commons/hornetq-commons.iml
trunk/hornetq-core-client/hornetq-core-client.iml
trunk/hornetq-core/hornetq-core.iml
trunk/hornetq-jboss-as-integration/hornetq-jboss-as-integration.iml
trunk/hornetq-jms-client/hornetq-jms-client.iml
trunk/hornetq-jms/hornetq-jms.iml
trunk/hornetq-journal/hornetq-journal.iml
trunk/hornetq-ra/hornetq-ra-jar/hornetq-ra.iml
trunk/hornetq-ra/hornetq-ra-rar/hornetq-rar.iml
trunk/hornetq-ra/hornetq-rar-pom.iml
trunk/hornetq-rest/hornetq-rest-all.iml
trunk/hornetq-rest/hornetq-rest/hornetq-rest.iml
trunk/hornetq-service-sar/hornetq-service-sar.iml
trunk/hornetq-spring-integration/hornetq-spring-integration.iml
trunk/hornetq-twitter-integration/hornetq-twitter-integration.iml
trunk/hornetq.iml
trunk/hornetq.ipr
trunk/hornetq.iws
trunk/tests/concurrent-tests/concurrent-tests.iml
trunk/tests/hornetq-tests-pom.iml
trunk/tests/integration-tests/integration-tests.iml
trunk/tests/jms-tests/jms-tests.iml
trunk/tests/joram-tests/joram-tests.iml
trunk/tests/performance-tests/performance-tests.iml
trunk/tests/soak-tests/soak-tests.iml
trunk/tests/stress-tests/stress-tests.iml
trunk/tests/timing-tests/timing-tests.iml
trunk/tests/unit-tests/unit-tests.iml
Log:
removed intellij project files
Deleted: trunk/distribution/hornetq/hornetq (1).iml
===================================================================
--- trunk/distribution/hornetq/hornetq (1).iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/distribution/hornetq/hornetq (1).iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,20 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_5" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/resources" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- </component>
-</module>
-
Deleted: trunk/distribution/hornetq-distribution.iml
===================================================================
--- trunk/distribution/hornetq-distribution.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/distribution/hornetq-distribution.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,19 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_5" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/hornetq/src/main/resources" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- </component>
-</module>
-
Deleted: trunk/distribution/jnp-client/jnp-client.iml
===================================================================
--- trunk/distribution/jnp-client/jnp-client.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/distribution/jnp-client/jnp-client.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,19 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <exclude-output />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- </component>
-</module>
-
Deleted: trunk/docs/hornetq-docs.iml
===================================================================
--- trunk/docs/hornetq-docs.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/docs/hornetq-docs.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,14 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_5" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <exclude-output />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- </component>
-</module>
-
Deleted: trunk/docs/quickstart-guide/HornetQ_QuickStart_Guide-en.iml
===================================================================
--- trunk/docs/quickstart-guide/HornetQ_QuickStart_Guide-en.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/docs/quickstart-guide/HornetQ_QuickStart_Guide-en.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,13 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_5" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- </component>
-</module>
-
Deleted: trunk/docs/rest-manual/HornetQ_Rest_Manual-en.iml
===================================================================
--- trunk/docs/rest-manual/HornetQ_Rest_Manual-en.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/docs/rest-manual/HornetQ_Rest_Manual-en.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,13 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_5" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- </component>
-</module>
-
Deleted: trunk/docs/user-manual/HornetQ_User_Manual-en.iml
===================================================================
--- trunk/docs/user-manual/HornetQ_User_Manual-en.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/docs/user-manual/HornetQ_User_Manual-en.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,13 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_5" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- </component>
-</module>
-
Deleted: trunk/examples/hornetq-examples.iml
===================================================================
--- trunk/examples/hornetq-examples.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/examples/hornetq-examples.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,14 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_5" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/resources" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- </component>
-</module>
-
Deleted: trunk/examples/jms/hornetq-jms-examples.iml
===================================================================
--- trunk/examples/jms/hornetq-jms-examples.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/examples/jms/hornetq-jms-examples.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,149 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module relativePaths="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" inherit-compiler-output="true">
- <exclude-output />
- <content url="file://$MODULE_DIR$/../common">
- <sourceFolder url="file://$MODULE_DIR$/../common/src" isTestSource="false" />
- </content>
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/application-layer-failover/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/bridge/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/browser/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/client-kickoff/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/client-side-load-balancing/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/clustered-durable-subscription/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/clustered-queue/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/clustered-topic/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/consumer-rate-limit/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/dead-letter/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/delayed-redelivery/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/divert/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/durable-subscription/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/embedded/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/expiry/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/http-transport/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/instantiate-connection-factory/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/interceptor/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/jmx/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/large-message/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/last-value-queue/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/management-notifications/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/management/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/message-counters/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/message-group/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/message-group2/src" isTestSource="true" />
- <sourceFolder url="file://$MODULE_DIR$/message-priority/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/no-consumer-buffering/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/non-transaction-failover/src" isTestSource="true" />
- <sourceFolder url="file://$MODULE_DIR$/paging/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/pre-acknowledge/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/producer-rate-limit/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/queue-message-redistribution/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/queue-requestor/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/queue-selector/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/queue/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/reattach-node/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/request-reply/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/scheduled-message/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/security/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/ssl-enabled/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/static-selector/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/symmetric-cluster/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/temp-queue/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/topic-hierarchies/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/topic-selector-example1/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/topic-selector-example2/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/topic/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/transactional/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/xa-heuristic/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/xa-receive/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/xa-send/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/xa-with-jta/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/applet/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/clustered-grouping/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/clustered-standalone/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/jaas/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/jms-bridge/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/perf/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/send-acknowledgements/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/static-selector-jms/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/transaction-failover/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/multiple-failover/src" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/browser/build" />
- <excludeFolder url="file://$MODULE_DIR$/browser/logs" />
- <excludeFolder url="file://$MODULE_DIR$/browser/server0/build" />
- <excludeFolder url="file://$MODULE_DIR$/browser/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/browser/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/build" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-queue/build" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-queue/logs" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-queue/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-queue/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-queue/server1/data" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-queue/server1/logs" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-topic/build" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-topic/logs" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-topic/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-topic/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-topic/server1/data" />
- <excludeFolder url="file://$MODULE_DIR$/clustered-topic/server1/logs" />
- <excludeFolder url="file://$MODULE_DIR$/common/build" />
- <excludeFolder url="file://$MODULE_DIR$/dead-letter/build" />
- <excludeFolder url="file://$MODULE_DIR$/dead-letter/logs" />
- <excludeFolder url="file://$MODULE_DIR$/dead-letter/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/dead-letter/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/durable-subscription/build" />
- <excludeFolder url="file://$MODULE_DIR$/durable-subscription/logs" />
- <excludeFolder url="file://$MODULE_DIR$/durable-subscription/server0/build" />
- <excludeFolder url="file://$MODULE_DIR$/durable-subscription/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/durable-subscription/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/expiry/build" />
- <excludeFolder url="file://$MODULE_DIR$/expiry/logs" />
- <excludeFolder url="file://$MODULE_DIR$/expiry/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/expiry/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/large-message/build" />
- <excludeFolder url="file://$MODULE_DIR$/large-message/logs" />
- <excludeFolder url="file://$MODULE_DIR$/large-message/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/large-message/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/message-group2/build" />
- <excludeFolder url="file://$MODULE_DIR$/message-group2/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/output" />
- <excludeFolder url="file://$MODULE_DIR$/paging/build" />
- <excludeFolder url="file://$MODULE_DIR$/paging/logs" />
- <excludeFolder url="file://$MODULE_DIR$/paging/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/paging/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/queue-requestor/build" />
- <excludeFolder url="file://$MODULE_DIR$/queue-requestor/logs" />
- <excludeFolder url="file://$MODULE_DIR$/queue-requestor/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/queue-requestor/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/queue/build" />
- <excludeFolder url="file://$MODULE_DIR$/queue/logs" />
- <excludeFolder url="file://$MODULE_DIR$/queue/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/queue/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/request-reply/build" />
- <excludeFolder url="file://$MODULE_DIR$/request-reply/logs" />
- <excludeFolder url="file://$MODULE_DIR$/request-reply/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/request-reply/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/security/build" />
- <excludeFolder url="file://$MODULE_DIR$/security/logs" />
- <excludeFolder url="file://$MODULE_DIR$/security/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/security/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/temp-queue/build" />
- <excludeFolder url="file://$MODULE_DIR$/temp-queue/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/temp-queue/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/topic/build" />
- <excludeFolder url="file://$MODULE_DIR$/topic/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/topic/server0/logs" />
- <excludeFolder url="file://$MODULE_DIR$/transactional/build" />
- <excludeFolder url="file://$MODULE_DIR$/transactional/server0/data" />
- <excludeFolder url="file://$MODULE_DIR$/transactional/server0/logs" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq" />
- <orderEntry type="library" name="messaging-jms-examples" level="project" />
- <orderEntry type="library" name="messaging_jars" level="project" />
- <orderEntry type="library" name="stomp" level="application" />
- </component>
-</module>
-
Deleted: trunk/hornetq-bootstrap/hornetq-bootstrap.iml
===================================================================
--- trunk/hornetq-bootstrap/hornetq-bootstrap.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-bootstrap/hornetq-bootstrap.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,33 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/${project.build.directory}/classes" />
- <excludeFolder url="file://$MODULE_DIR$/${project.build.directory}/test-classes" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-commons/hornetq-commons.iml
===================================================================
--- trunk/hornetq-commons/hornetq-commons.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-commons/hornetq-commons.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,19 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <exclude-output />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="library" scope="TEST" name="Maven: junit:junit:3.8.2" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-core/hornetq-core.iml
===================================================================
--- trunk/hornetq-core/hornetq-core.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-core/hornetq-core.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,19 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/target/generated-sources/javacc" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/src/main/resources" isTestSource="false" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- </component>
-</module>
-
Deleted: trunk/hornetq-core-client/hornetq-core-client.iml
===================================================================
--- trunk/hornetq-core-client/hornetq-core-client.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-core-client/hornetq-core-client.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,18 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- </component>
-</module>
-
Deleted: trunk/hornetq-jboss-as-integration/hornetq-jboss-as-integration.iml
===================================================================
--- trunk/hornetq-jboss-as-integration/hornetq-jboss-as-integration.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-jboss-as-integration/hornetq-jboss-as-integration.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,28 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.transaction:jboss-transaction-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.20070913080910" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-jms/hornetq-jms.iml
===================================================================
--- trunk/hornetq-jms/hornetq-jms.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-jms/hornetq-jms.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,23 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/src/main/resources" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.jms:jboss-jms-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.transaction:jboss-transaction-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-jms-client/hornetq-jms-client.iml
===================================================================
--- trunk/hornetq-jms-client/hornetq-jms-client.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-jms-client/hornetq-jms-client.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,22 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.jms:jboss-jms-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.transaction:jboss-transaction-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-journal/hornetq-journal.iml
===================================================================
--- trunk/hornetq-journal/hornetq-journal.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-journal/hornetq-journal.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,18 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <exclude-output />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-ra/hornetq-ra-jar/hornetq-ra.iml
===================================================================
--- trunk/hornetq-ra/hornetq-ra-jar/hornetq-ra.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-ra/hornetq-ra-jar/hornetq-ra.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,26 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" scope="PROVIDED" />
- <orderEntry type="module" module-name="hornetq-commons" scope="PROVIDED" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" scope="PROVIDED" />
- <orderEntry type="module" module-name="hornetq-jms" scope="PROVIDED" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.spec.javax.jms:jboss-jms-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.spec.javax.transaction:jboss-transaction-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-ra/hornetq-ra-rar/hornetq-rar.iml
===================================================================
--- trunk/hornetq-ra/hornetq-ra-rar/hornetq-rar.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-ra/hornetq-ra-rar/hornetq-rar.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,18 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/resources" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-jms-client" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-core-client" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-ra/hornetq-rar-pom.iml
===================================================================
--- trunk/hornetq-ra/hornetq-rar-pom.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-ra/hornetq-rar-pom.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,13 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- </component>
-</module>
-
Deleted: trunk/hornetq-rest/hornetq-rest/hornetq-rest.iml
===================================================================
--- trunk/hornetq-rest/hornetq-rest/hornetq-rest.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-rest/hornetq-rest/hornetq-rest.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,46 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <sourceFolder url="file://$MODULE_DIR$/src/test/resources" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.hornetq:hornetq-core:2.2.3-SNAPSHOT" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.hornetq:hornetq-jms:2.2.3-SNAPSHOT" level="project" />
- <orderEntry type="module" module-name="hornetq-core" scope="PROVIDED" />
- <orderEntry type="module" module-name="hornetq-commons" scope="PROVIDED" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" scope="PROVIDED" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.resteasy:resteasy-jaxrs:2.1.0.GA" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.resteasy:jaxrs-api:2.1.0.GA" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.scannotation:scannotation:1.0.2" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: javassist:javassist:3.6.0.GA" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: javax.annotation:jsr250-api:1.0" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: javax.activation:activation:1.1" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: commons-httpclient:commons-httpclient:3.1" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: commons-logging:commons-logging:1.0.4" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: commons-codec:commons-codec:1.2" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: net.jcip:jcip-annotations:1.0" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.resteasy:resteasy-jaxb-provider:2.1.0.GA" level="project" />
- <orderEntry type="library" scope="TEST" name="Maven: org.jboss.resteasy:resteasy-jackson-provider:2.1.0.GA" level="project" />
- <orderEntry type="library" scope="TEST" name="Maven: org.codehaus.jackson:jackson-core-asl:1.6.3" level="project" />
- <orderEntry type="library" scope="TEST" name="Maven: org.codehaus.jackson:jackson-mapper-asl:1.6.3" level="project" />
- <orderEntry type="library" scope="TEST" name="Maven: org.codehaus.jackson:jackson-jaxrs:1.6.3" level="project" />
- <orderEntry type="library" scope="TEST" name="Maven: org.codehaus.jackson:jackson-xc:1.6.3" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" scope="PROVIDED" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.spec.javax.jms:jboss-jms-api_1.1_spec:1.0.0.Beta1" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: org.jboss.spec.javax.transaction:jboss-transaction-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:4.1" level="project" />
- <orderEntry type="library" scope="PROVIDED" name="Maven: javax.servlet:servlet-api:2.5" level="project" />
- <orderEntry type="library" scope="TEST" name="Maven: org.jboss.resteasy:tjws:2.1.0.GA" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-rest/hornetq-rest-all.iml
===================================================================
--- trunk/hornetq-rest/hornetq-rest-all.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-rest/hornetq-rest-all.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,14 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <exclude-output />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- </component>
-</module>
-
Deleted: trunk/hornetq-service-sar/hornetq-service-sar.iml
===================================================================
--- trunk/hornetq-service-sar/hornetq-service-sar.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-service-sar/hornetq-service-sar.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.jms:jboss-jms-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.transaction:jboss-transaction-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-jboss-as-integration" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.20070913080910" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-spring-integration/hornetq-spring-integration.iml
===================================================================
--- trunk/hornetq-spring-integration/hornetq-spring-integration.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-spring-integration/hornetq-spring-integration.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,33 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.jms:jboss-jms-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.spec.javax.transaction:jboss-transaction-api_1.1_spec:1.0.0.Final" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-core:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-asm:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: commons-logging:commons-logging:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-beans:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-context:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-aop:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: aopalliance:aopalliance:1.0" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-expression:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-jms:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-tx:3.0.3.RELEASE" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq-twitter-integration/hornetq-twitter-integration.iml
===================================================================
--- trunk/hornetq-twitter-integration/hornetq-twitter-integration.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq-twitter-integration/hornetq-twitter-integration.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,20 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="module" module-name="hornetq-commons" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.16" level="project" />
- <orderEntry type="module" module-name="hornetq-journal" />
- <orderEntry type="library" name="Maven: org.twitter4j:twitter4j-core:2.1.2" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq.iml
===================================================================
--- trunk/hornetq.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,49 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module org.jetbrains.idea.maven.project.MavenProjectsManager.isMavenModule="true" relativePaths="true" type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/build/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/native/src" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/hornetq-core/src/java" isTestSource="false" />
- <excludeFolder url="file://$MODULE_DIR$/ObjectStore" />
- <excludeFolder url="file://$MODULE_DIR$/build/api" />
- <excludeFolder url="file://$MODULE_DIR$/build/classes" />
- <excludeFolder url="file://$MODULE_DIR$/build/jars" />
- <excludeFolder url="file://$MODULE_DIR$/build/messaging-2.0.0.BETA1" />
- <excludeFolder url="file://$MODULE_DIR$/build/messaging-2.0.0.BETA1-SNAPSHOT" />
- <excludeFolder url="file://$MODULE_DIR$/build/messaging-2.0.0.BETA3" />
- <excludeFolder url="file://$MODULE_DIR$/build/messaging-2.0.0.alpha1" />
- <excludeFolder url="file://$MODULE_DIR$/classes" />
- <excludeFolder url="file://$MODULE_DIR$/data" />
- <excludeFolder url="file://$MODULE_DIR$/docs/quickstart-guide/build" />
- <excludeFolder url="file://$MODULE_DIR$/docs/user-manual/build" />
- <excludeFolder url="file://$MODULE_DIR$/examples/jms/build" />
- <excludeFolder url="file://$MODULE_DIR$/examples/jms/common/build" />
- <excludeFolder url="file://$MODULE_DIR$/examples/jms/queue/build" />
- <excludeFolder url="file://$MODULE_DIR$/journal-test" />
- <excludeFolder url="file://$MODULE_DIR$/logs" />
- <excludeFolder url="file://$MODULE_DIR$/output" />
- <excludeFolder url="file://$MODULE_DIR$/output/classes" />
- <excludeFolder url="file://$MODULE_DIR$/output/etc" />
- <excludeFolder url="file://$MODULE_DIR$/output/jar" />
- <excludeFolder url="file://$MODULE_DIR$/output/lib" />
- <excludeFolder url="file://$MODULE_DIR$/output/scoped-sar" />
- <excludeFolder url="file://$MODULE_DIR$/production" />
- <excludeFolder url="file://$MODULE_DIR$/release" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- <excludeFolder url="file://$MODULE_DIR$/test" />
- <excludeFolder url="file://$MODULE_DIR$/tests/ObjectStore" />
- <excludeFolder url="file://$MODULE_DIR$/tests/build" />
- <excludeFolder url="file://$MODULE_DIR$/tests/jms-tests/build" />
- <excludeFolder url="file://$MODULE_DIR$/tests/lib/jdbc-drivers" />
- <excludeFolder url="file://$MODULE_DIR$/tests/output" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="library" name="messaging_jars" level="project" />
- <orderEntry type="library" name="ant 1.7.1" level="project" />
- </component>
-</module>
-
Deleted: trunk/hornetq.ipr
===================================================================
--- trunk/hornetq.ipr 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq.ipr 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,1171 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<project version="4">
- <component name="ASMPluginConfiguration">
- <asm skipDebug="false" skipFrames="false" skipCode="false" expandFrames="false" />
- <groovy codeStyle="LEGACY" />
- </component>
- <component name="AntConfiguration">
- <defaultAnt bundledAnt="true" />
- <buildFile url="file://$PROJECT_DIR$/build-hornetq.xml">
- <additionalClassPath />
- <antReference projectDefault="true" />
- <customJdkName value="" />
- <maximumHeapSize value="128" />
- <maximumStackSize value="32" />
- <properties />
- </buildFile>
- </component>
- <component name="BuildJarProjectSettings">
- <option name="BUILD_JARS_ON_MAKE" value="false" />
- </component>
- <component name="CodeStyleProjectProfileManger">
- <option name="PROJECT_PROFILE" />
- <option name="USE_PROJECT_LEVEL_SETTINGS" value="false" />
- </component>
- <component name="CodeStyleSettingsManager">
- <option name="PER_PROJECT_SETTINGS">
- <value>
- <ADDITIONAL_INDENT_OPTIONS fileType="java">
- <option name="INDENT_SIZE" value="4" />
- <option name="CONTINUATION_INDENT_SIZE" value="8" />
- <option name="TAB_SIZE" value="4" />
- <option name="USE_TAB_CHARACTER" value="false" />
- <option name="SMART_TABS" value="false" />
- <option name="LABEL_INDENT_SIZE" value="0" />
- <option name="LABEL_INDENT_ABSOLUTE" value="false" />
- <option name="USE_RELATIVE_INDENTS" value="false" />
- </ADDITIONAL_INDENT_OPTIONS>
- <ADDITIONAL_INDENT_OPTIONS fileType="jsp">
- <option name="INDENT_SIZE" value="4" />
- <option name="CONTINUATION_INDENT_SIZE" value="8" />
- <option name="TAB_SIZE" value="4" />
- <option name="USE_TAB_CHARACTER" value="false" />
- <option name="SMART_TABS" value="false" />
- <option name="LABEL_INDENT_SIZE" value="0" />
- <option name="LABEL_INDENT_ABSOLUTE" value="false" />
- <option name="USE_RELATIVE_INDENTS" value="false" />
- </ADDITIONAL_INDENT_OPTIONS>
- <ADDITIONAL_INDENT_OPTIONS fileType="xml">
- <option name="INDENT_SIZE" value="4" />
- <option name="CONTINUATION_INDENT_SIZE" value="8" />
- <option name="TAB_SIZE" value="4" />
- <option name="USE_TAB_CHARACTER" value="false" />
- <option name="SMART_TABS" value="false" />
- <option name="LABEL_INDENT_SIZE" value="0" />
- <option name="LABEL_INDENT_ABSOLUTE" value="false" />
- <option name="USE_RELATIVE_INDENTS" value="false" />
- </ADDITIONAL_INDENT_OPTIONS>
- </value>
- </option>
- </component>
- <component name="CompilerConfiguration">
- <option name="DEFAULT_COMPILER" value="Javac" />
- <resourceExtensions>
- <entry name=".+\.(properties|xml|html|dtd|tld)" />
- <entry name=".+\.(gif|png|jpeg|jpg)" />
- </resourceExtensions>
- <wildcardResourcePatterns>
- <entry name="?*.properties" />
- <entry name="?*.xml" />
- <entry name="?*.gif" />
- <entry name="?*.png" />
- <entry name="?*.jpeg" />
- <entry name="?*.jpg" />
- <entry name="?*.html" />
- <entry name="?*.dtd" />
- <entry name="?*.tld" />
- </wildcardResourcePatterns>
- <annotationProcessing enabled="false" useClasspath="true" />
- </component>
- <component name="CopyrightManager" default="">
- <copyright>
- <option name="notice" value="Copyright 2009 Red Hat, Inc. Red Hat 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." />
- <option name="keyword" value="Copyright" />
- <option name="allowReplaceKeyword" value="" />
- <option name="myName" value="new" />
- <option name="myLocal" value="true" />
- </copyright>
- <module2copyright>
- <element module="All" copyright="new" />
- </module2copyright>
- </component>
- <component name="CppTools.Loader" reportImplicitCastToBool="false" reportNameReferencedOnce="false" warnedAboutFileOutOfSourceRoot="true" version="3" currentProject="$PROJECT_DIR$/native/Makefile" compilerSelect="AUTO" />
- <component name="DependenciesAnalyzeManager">
- <option name="myForwardDirection" value="false" />
- </component>
- <component name="DependencyValidationManager">
- <option name="SKIP_IMPORT_STATEMENTS" value="false" />
- </component>
- <component name="EclipseCompilerSettings">
- <option name="GENERATE_NO_WARNINGS" value="true" />
- <option name="DEPRECATION" value="false" />
- </component>
- <component name="EclipseEmbeddedCompilerSettings">
- <option name="DEBUGGING_INFO" value="true" />
- <option name="GENERATE_NO_WARNINGS" value="true" />
- <option name="DEPRECATION" value="false" />
- <option name="ADDITIONAL_OPTIONS_STRING" value="" />
- <option name="MAXIMUM_HEAP_SIZE" value="128" />
- </component>
- <component name="Encoding" useUTFGuessing="true" native2AsciiForPropertiesFiles="false" />
- <component name="EntryPointsManager">
- <entry_points version="2.0" />
- </component>
- <component name="ExportToHTMLSettings">
- <option name="PRINT_LINE_NUMBERS" value="false" />
- <option name="OPEN_IN_BROWSER" value="false" />
- <option name="OUTPUT_DIRECTORY" />
- </component>
- <component name="FacetAutodetectingManager">
- <autodetection-disabled>
- <facet-type id="ejb">
- <modules>
- <module name="messaging" />
- </modules>
- </facet-type>
- <facet-type id="javaeeApplication">
- <modules>
- <module name="hornetq-javaee-examples">
- <files>
- <file url="file://$PROJECT_DIR$/examples/javaee/servlet-transport/config/META-INF/application.xml" />
- </files>
- </module>
- <module name="messaging" />
- </modules>
- </facet-type>
- <facet-type id="web">
- <modules>
- <module name="hornetq-javaee-examples">
- <files>
- <file url="file://$PROJECT_DIR$/examples/javaee/servlet-transport/config/WEB-INF/web.xml" />
- </files>
- </module>
- <module name="messaging" />
- </modules>
- </facet-type>
- </autodetection-disabled>
- </component>
- <component name="IdProvider" IDEtalkID="6A074DEDEA8BB8F84C6214EB1D2AF8C8" />
- <component name="InspectionProjectProfileManager">
- <profiles>
- <profile version="1.0" is_locked="false">
- <option name="myName" value="Project Default" />
- <option name="myLocal" value="false" />
- <inspection_tool class="JavadocReference" enabled="false" level="ERROR" enabled_by_default="false" />
- </profile>
- </profiles>
- <option name="PROJECT_PROFILE" value="Project Default" />
- <option name="USE_PROJECT_PROFILE" value="true" />
- <version value="1.0" />
- </component>
- <component name="IntelliJadProjectConfigComponent">
- <config>
- <stat type="boolean">false</stat>
- <nocode type="boolean">false</nocode>
- <nodos type="boolean">false</nodos>
- <create-output-directory type="boolean">false</create-output-directory>
- <noinner type="boolean">false</noinner>
- <pf type="string">_fld</pf>
- <b type="boolean">false</b>
- <af type="boolean">false</af>
- <safe type="boolean">false</safe>
- <lnc type="boolean">false</lnc>
- <lradix type="integer">10</lradix>
- <v type="boolean">false</v>
- <noctor type="boolean">false</noctor>
- <nonlb type="boolean">false</nonlb>
- <ff type="boolean">false</ff>
- <pp type="string">_prm</pp>
- <read-only type="boolean">false</read-only>
- <o type="boolean">false</o>
- <nolvt type="boolean">false</nolvt>
- <nl type="boolean">false</nl>
- <noconv type="boolean">false</noconv>
- <pm type="string">_mth</pm>
- <nocast type="boolean">false</nocast>
- <jad-path type="string" />
- <r type="boolean">false</r>
- <sort type="boolean">false</sort>
- <exclusion-table-model type="table-model" model-class="net.stevechaloner.intellijad.config.ExclusionTableModel" content-types="string,boolean,boolean" />
- <always-exclude-recursively type="boolean">false</always-exclude-recursively>
- <d type="string" />
- <pe type="string">_ex</pe>
- <l type="integer">64</l>
- <decompile-to-memory type="boolean">true</decompile-to-memory>
- <use-project-specific-settings type="boolean">false</use-project-specific-settings>
- <clear type="boolean">false</clear>
- <nofd type="boolean">false</nofd>
- <clear-and-close-console-on-success type="boolean">false</clear-and-close-console-on-success>
- <indentation type="integer">4</indentation>
- <a type="boolean">false</a>
- <dead type="boolean">false</dead>
- <noclass type="boolean">false</noclass>
- <i type="boolean">false</i>
- <pc type="string">_cls</pc>
- <t type="boolean">false</t>
- <decompile-on-navigation type="string">Always</decompile-on-navigation>
- <f type="boolean">false</f>
- <pv type="integer">3</pv>
- <radix type="integer">10</radix>
- <pa type="string" />
- <space type="boolean">false</space>
- <reformat-according-to-style type="boolean">false</reformat-according-to-style>
- <s type="string">java</s>
- <dis type="boolean">false</dis>
- <pl type="string">_lcl</pl>
- </config>
- </component>
- <component name="JavacSettings">
- <option name="ADDITIONAL_OPTIONS_STRING" value="-target 1.5" />
- </component>
- <component name="JavadocGenerationManager">
- <option name="OUTPUT_DIRECTORY" />
- <option name="OPTION_SCOPE" value="protected" />
- <option name="OPTION_HIERARCHY" value="true" />
- <option name="OPTION_NAVIGATOR" value="true" />
- <option name="OPTION_INDEX" value="true" />
- <option name="OPTION_SEPARATE_INDEX" value="true" />
- <option name="OPTION_DOCUMENT_TAG_USE" value="false" />
- <option name="OPTION_DOCUMENT_TAG_AUTHOR" value="false" />
- <option name="OPTION_DOCUMENT_TAG_VERSION" value="false" />
- <option name="OPTION_DOCUMENT_TAG_DEPRECATED" value="true" />
- <option name="OPTION_DEPRECATED_LIST" value="true" />
- <option name="OTHER_OPTIONS" value="" />
- <option name="HEAP_SIZE" />
- <option name="LOCALE" />
- <option name="OPEN_IN_BROWSER" value="true" />
- </component>
- <component name="LogConsolePreferences">
- <option name="FILTER_ERRORS" value="false" />
- <option name="FILTER_WARNINGS" value="false" />
- <option name="FILTER_INFO" value="true" />
- <option name="CUSTOM_FILTER" />
- </component>
- <component name="MavenProjectsManager">
- <option name="originalFiles">
- <list>
- <option value="$PROJECT_DIR$/pom.xml" />
- <option value="$PROJECT_DIR$/pom.xml" />
- </list>
- </option>
- </component>
- <component name="Palette2">
- <group name="Swing">
- <item class="com.intellij.uiDesigner.HSpacer" tooltip-text="Horizontal Spacer" icon="/com/intellij/uiDesigner/icons/hspacer.png" removable="false" auto-create-binding="false" can-attach-label="false">
- <default-constraints vsize-policy="1" hsize-policy="6" anchor="0" fill="1" />
- </item>
- <item class="com.intellij.uiDesigner.VSpacer" tooltip-text="Vertical Spacer" icon="/com/intellij/uiDesigner/icons/vspacer.png" removable="false" auto-create-binding="false" can-attach-label="false">
- <default-constraints vsize-policy="6" hsize-policy="1" anchor="0" fill="2" />
- </item>
- <item class="javax.swing.JPanel" icon="/com/intellij/uiDesigner/icons/panel.png" removable="false" auto-create-binding="false" can-attach-label="false">
- <default-constraints vsize-policy="3" hsize-policy="3" anchor="0" fill="3" />
- </item>
- <item class="javax.swing.JScrollPane" icon="/com/intellij/uiDesigner/icons/scrollPane.png" removable="false" auto-create-binding="false" can-attach-label="true">
- <default-constraints vsize-policy="7" hsize-policy="7" anchor="0" fill="3" />
- </item>
- <item class="javax.swing.JButton" icon="/com/intellij/uiDesigner/icons/button.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="0" hsize-policy="3" anchor="0" fill="1" />
- <initial-values>
- <property name="text" value="Button" />
- </initial-values>
- </item>
- <item class="javax.swing.JRadioButton" icon="/com/intellij/uiDesigner/icons/radioButton.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="0" hsize-policy="3" anchor="8" fill="0" />
- <initial-values>
- <property name="text" value="RadioButton" />
- </initial-values>
- </item>
- <item class="javax.swing.JCheckBox" icon="/com/intellij/uiDesigner/icons/checkBox.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="0" hsize-policy="3" anchor="8" fill="0" />
- <initial-values>
- <property name="text" value="CheckBox" />
- </initial-values>
- </item>
- <item class="javax.swing.JLabel" icon="/com/intellij/uiDesigner/icons/label.png" removable="false" auto-create-binding="false" can-attach-label="false">
- <default-constraints vsize-policy="0" hsize-policy="0" anchor="8" fill="0" />
- <initial-values>
- <property name="text" value="Label" />
- </initial-values>
- </item>
- <item class="javax.swing.JTextField" icon="/com/intellij/uiDesigner/icons/textField.png" removable="false" auto-create-binding="true" can-attach-label="true">
- <default-constraints vsize-policy="0" hsize-policy="6" anchor="8" fill="1">
- <preferred-size width="150" height="-1" />
- </default-constraints>
- </item>
- <item class="javax.swing.JPasswordField" icon="/com/intellij/uiDesigner/icons/passwordField.png" removable="false" auto-create-binding="true" can-attach-label="true">
- <default-constraints vsize-policy="0" hsize-policy="6" anchor="8" fill="1">
- <preferred-size width="150" height="-1" />
- </default-constraints>
- </item>
- <item class="javax.swing.JFormattedTextField" icon="/com/intellij/uiDesigner/icons/formattedTextField.png" removable="false" auto-create-binding="true" can-attach-label="true">
- <default-constraints vsize-policy="0" hsize-policy="6" anchor="8" fill="1">
- <preferred-size width="150" height="-1" />
- </default-constraints>
- </item>
- <item class="javax.swing.JTextArea" icon="/com/intellij/uiDesigner/icons/textArea.png" removable="false" auto-create-binding="true" can-attach-label="true">
- <default-constraints vsize-policy="6" hsize-policy="6" anchor="0" fill="3">
- <preferred-size width="150" height="50" />
- </default-constraints>
- </item>
- <item class="javax.swing.JTextPane" icon="/com/intellij/uiDesigner/icons/textPane.png" removable="false" auto-create-binding="true" can-attach-label="true">
- <default-constraints vsize-policy="6" hsize-policy="6" anchor="0" fill="3">
- <preferred-size width="150" height="50" />
- </default-constraints>
- </item>
- <item class="javax.swing.JEditorPane" icon="/com/intellij/uiDesigner/icons/editorPane.png" removable="false" auto-create-binding="true" can-attach-label="true">
- <default-constraints vsize-policy="6" hsize-policy="6" anchor="0" fill="3">
- <preferred-size width="150" height="50" />
- </default-constraints>
- </item>
- <item class="javax.swing.JComboBox" icon="/com/intellij/uiDesigner/icons/comboBox.png" removable="false" auto-create-binding="true" can-attach-label="true">
- <default-constraints vsize-policy="0" hsize-policy="2" anchor="8" fill="1" />
- </item>
- <item class="javax.swing.JTable" icon="/com/intellij/uiDesigner/icons/table.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="6" hsize-policy="6" anchor="0" fill="3">
- <preferred-size width="150" height="50" />
- </default-constraints>
- </item>
- <item class="javax.swing.JList" icon="/com/intellij/uiDesigner/icons/list.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="6" hsize-policy="2" anchor="0" fill="3">
- <preferred-size width="150" height="50" />
- </default-constraints>
- </item>
- <item class="javax.swing.JTree" icon="/com/intellij/uiDesigner/icons/tree.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="6" hsize-policy="6" anchor="0" fill="3">
- <preferred-size width="150" height="50" />
- </default-constraints>
- </item>
- <item class="javax.swing.JTabbedPane" icon="/com/intellij/uiDesigner/icons/tabbedPane.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="3" hsize-policy="3" anchor="0" fill="3">
- <preferred-size width="200" height="200" />
- </default-constraints>
- </item>
- <item class="javax.swing.JSplitPane" icon="/com/intellij/uiDesigner/icons/splitPane.png" removable="false" auto-create-binding="false" can-attach-label="false">
- <default-constraints vsize-policy="3" hsize-policy="3" anchor="0" fill="3">
- <preferred-size width="200" height="200" />
- </default-constraints>
- </item>
- <item class="javax.swing.JSpinner" icon="/com/intellij/uiDesigner/icons/spinner.png" removable="false" auto-create-binding="true" can-attach-label="true">
- <default-constraints vsize-policy="0" hsize-policy="6" anchor="8" fill="1" />
- </item>
- <item class="javax.swing.JSlider" icon="/com/intellij/uiDesigner/icons/slider.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="0" hsize-policy="6" anchor="8" fill="1" />
- </item>
- <item class="javax.swing.JSeparator" icon="/com/intellij/uiDesigner/icons/separator.png" removable="false" auto-create-binding="false" can-attach-label="false">
- <default-constraints vsize-policy="6" hsize-policy="6" anchor="0" fill="3" />
- </item>
- <item class="javax.swing.JProgressBar" icon="/com/intellij/uiDesigner/icons/progressbar.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="0" hsize-policy="6" anchor="0" fill="1" />
- </item>
- <item class="javax.swing.JToolBar" icon="/com/intellij/uiDesigner/icons/toolbar.png" removable="false" auto-create-binding="false" can-attach-label="false">
- <default-constraints vsize-policy="0" hsize-policy="6" anchor="0" fill="1">
- <preferred-size width="-1" height="20" />
- </default-constraints>
- </item>
- <item class="javax.swing.JToolBar$Separator" icon="/com/intellij/uiDesigner/icons/toolbarSeparator.png" removable="false" auto-create-binding="false" can-attach-label="false">
- <default-constraints vsize-policy="0" hsize-policy="0" anchor="0" fill="1" />
- </item>
- <item class="javax.swing.JScrollBar" icon="/com/intellij/uiDesigner/icons/scrollbar.png" removable="false" auto-create-binding="true" can-attach-label="false">
- <default-constraints vsize-policy="6" hsize-policy="0" anchor="0" fill="2" />
- </item>
- </group>
- </component>
- <component name="ProjectDetails">
- <option name="projectName" value="messaging" />
- </component>
- <component name="ProjectDictionaryState">
- <dictionary name="andy">
- <words>
- <w>remoting</w>
- </words>
- </dictionary>
- </component>
- <component name="ProjectKey">
- <option name="state" value="https://svn.jboss.org/repos/hornetq/trunk/hornetq.ipr" />
- </component>
- <component name="ProjectModuleManager">
- <modules>
- <module fileurl="file://$PROJECT_DIR$/docs/quickstart-guide/HornetQ_QuickStart_Guide-en.iml" filepath="$PROJECT_DIR$/docs/quickstart-guide/HornetQ_QuickStart_Guide-en.iml" />
- <module fileurl="file://$PROJECT_DIR$/docs/rest-manual/HornetQ_Rest_Manual-en.iml" filepath="$PROJECT_DIR$/docs/rest-manual/HornetQ_Rest_Manual-en.iml" />
- <module fileurl="file://$PROJECT_DIR$/docs/user-manual/HornetQ_User_Manual-en.iml" filepath="$PROJECT_DIR$/docs/user-manual/HornetQ_User_Manual-en.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/concurrent-tests/concurrent-tests.iml" filepath="$PROJECT_DIR$/tests/concurrent-tests/concurrent-tests.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq.iml" filepath="$PROJECT_DIR$/hornetq.iml" />
- <module fileurl="file://$PROJECT_DIR$/distribution/hornetq/hornetq (1).iml" filepath="$PROJECT_DIR$/distribution/hornetq/hornetq (1).iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-bootstrap/hornetq-bootstrap.iml" filepath="$PROJECT_DIR$/hornetq-bootstrap/hornetq-bootstrap.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-commons/hornetq-commons.iml" filepath="$PROJECT_DIR$/hornetq-commons/hornetq-commons.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-core/hornetq-core.iml" filepath="$PROJECT_DIR$/hornetq-core/hornetq-core.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-core-client/hornetq-core-client.iml" filepath="$PROJECT_DIR$/hornetq-core-client/hornetq-core-client.iml" />
- <module fileurl="file://$PROJECT_DIR$/distribution/hornetq-distribution.iml" filepath="$PROJECT_DIR$/distribution/hornetq-distribution.iml" />
- <module fileurl="file://$PROJECT_DIR$/docs/hornetq-docs.iml" filepath="$PROJECT_DIR$/docs/hornetq-docs.iml" />
- <module fileurl="file://$PROJECT_DIR$/examples/hornetq-examples.iml" filepath="$PROJECT_DIR$/examples/hornetq-examples.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-jboss-as-integration/hornetq-jboss-as-integration.iml" filepath="$PROJECT_DIR$/hornetq-jboss-as-integration/hornetq-jboss-as-integration.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-jms/hornetq-jms.iml" filepath="$PROJECT_DIR$/hornetq-jms/hornetq-jms.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-jms-client/hornetq-jms-client.iml" filepath="$PROJECT_DIR$/hornetq-jms-client/hornetq-jms-client.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-journal/hornetq-journal.iml" filepath="$PROJECT_DIR$/hornetq-journal/hornetq-journal.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-ra/hornetq-ra-jar/hornetq-ra.iml" filepath="$PROJECT_DIR$/hornetq-ra/hornetq-ra-jar/hornetq-ra.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-ra/hornetq-ra-rar/hornetq-rar.iml" filepath="$PROJECT_DIR$/hornetq-ra/hornetq-ra-rar/hornetq-rar.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-ra/hornetq-rar-pom.iml" filepath="$PROJECT_DIR$/hornetq-ra/hornetq-rar-pom.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-rest/hornetq-rest/hornetq-rest.iml" filepath="$PROJECT_DIR$/hornetq-rest/hornetq-rest/hornetq-rest.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-rest/hornetq-rest-all.iml" filepath="$PROJECT_DIR$/hornetq-rest/hornetq-rest-all.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-service-sar/hornetq-service-sar.iml" filepath="$PROJECT_DIR$/hornetq-service-sar/hornetq-service-sar.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-spring-integration/hornetq-spring-integration.iml" filepath="$PROJECT_DIR$/hornetq-spring-integration/hornetq-spring-integration.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/hornetq-tests-pom.iml" filepath="$PROJECT_DIR$/tests/hornetq-tests-pom.iml" />
- <module fileurl="file://$PROJECT_DIR$/hornetq-twitter-integration/hornetq-twitter-integration.iml" filepath="$PROJECT_DIR$/hornetq-twitter-integration/hornetq-twitter-integration.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/integration-tests/integration-tests.iml" filepath="$PROJECT_DIR$/tests/integration-tests/integration-tests.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/jms-tests/jms-tests.iml" filepath="$PROJECT_DIR$/tests/jms-tests/jms-tests.iml" />
- <module fileurl="file://$PROJECT_DIR$/distribution/jnp-client/jnp-client.iml" filepath="$PROJECT_DIR$/distribution/jnp-client/jnp-client.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/joram-tests/joram-tests.iml" filepath="$PROJECT_DIR$/tests/joram-tests/joram-tests.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/performance-tests/performance-tests.iml" filepath="$PROJECT_DIR$/tests/performance-tests/performance-tests.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/soak-tests/soak-tests.iml" filepath="$PROJECT_DIR$/tests/soak-tests/soak-tests.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/stress-tests/stress-tests.iml" filepath="$PROJECT_DIR$/tests/stress-tests/stress-tests.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/timing-tests/timing-tests.iml" filepath="$PROJECT_DIR$/tests/timing-tests/timing-tests.iml" />
- <module fileurl="file://$PROJECT_DIR$/tests/unit-tests/unit-tests.iml" filepath="$PROJECT_DIR$/tests/unit-tests/unit-tests.iml" />
- </modules>
- </component>
- <component name="ProjectResources">
- <default-html-doctype>http://www.w3.org/1999/xhtml</default-html-doctype>
- </component>
- <component name="ProjectRootManager" version="2" languageLevel="JDK_1_5" assert-keyword="true" jdk-15="true" project-jdk-name="1.6" project-jdk-type="JavaSDK">
- <output url="file://$PROJECT_DIR$/classes" />
- </component>
- <component name="ResourceManagerContainer">
- <option name="myResourceBundles">
- <value>
- <list size="0" />
- </value>
- </option>
- </component>
- <component name="SvnBranchConfigurationManager">
- <option name="myConfigurationMap">
- <map>
- <entry key="$PROJECT_DIR$">
- <value>
- <SvnBranchConfiguration>
- <option name="branchMap">
- <map>
- <entry key="https://svn.jboss.org/repos/messaging/admin">
- <value>
- <list />
- </value>
- </entry>
- <entry key="https://svn.jboss.org/repos/messaging/branches">
- <value>
- <list />
- </value>
- </entry>
- <entry key="https://svn.jboss.org/repos/messaging/projects">
- <value>
- <list />
- </value>
- </entry>
- <entry key="https://svn.jboss.org/repos/messaging/tags">
- <value>
- <list />
- </value>
- </entry>
- </map>
- </option>
- <option name="branchUrls">
- <list>
- <option value="https://svn.jboss.org/repos/messaging/admin" />
- <option value="https://svn.jboss.org/repos/messaging/branches" />
- <option value="https://svn.jboss.org/repos/messaging/projects" />
- <option value="https://svn.jboss.org/repos/messaging/tags" />
- </list>
- </option>
- <option name="trunkUrl" value="https://svn.jboss.org/repos/messaging/trunk" />
- </SvnBranchConfiguration>
- </value>
- </entry>
- </map>
- </option>
- <option name="myVersion" value="124" />
- <option name="mySupportsUserInfoFilter" value="true" />
- </component>
- <component name="VcsDirectoryMappings">
- <mapping directory="" vcs="" />
- <mapping directory="$PROJECT_DIR$" vcs="svn" />
- </component>
- <component name="WebServicesPlugin" addRequiredLibraries="true" />
- <component name="com.intellij.jsf.UserDefinedFacesConfigs">
- <option name="USER_DEFINED_CONFIGS">
- <value>
- <list size="0" />
- </value>
- </option>
- </component>
- <component name="libraryTable">
- <library name="Maven: aopalliance:aopalliance:1.0">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/aopalliance/aopalliance/1.0/aopalliance-1.0.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/aopalliance/aopalliance/1.0/aopalliance-1.0-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/aopalliance/aopalliance/1.0/aopalliance-1.0-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: apache-logging:commons-logging:1.1.0.jboss">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/apache-logging/commons-logging/1.1.0.jboss/commons-logging-1.1.0.jboss.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/apache-logging/commons-logging/1.1.0.jboss/commons-logging-1.1.0.jboss-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/apache-logging/commons-logging/1.1.0.jboss/commons-logging-1.1.0.jboss-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: apache-xerces:xercesImpl:2.9.1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/apache-xerces/xercesImpl/2.9.1/xercesImpl-2.9.1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/apache-xerces/xercesImpl/2.9.1/xercesImpl-2.9.1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/apache-xerces/xercesImpl/2.9.1/xercesImpl-2.9.1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: apache-xerces:xml-apis:2.9.1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/apache-xerces/xml-apis/2.9.1/xml-apis-2.9.1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/apache-xerces/xml-apis/2.9.1/xml-apis-2.9.1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/apache-xerces/xml-apis/2.9.1/xml-apis-2.9.1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: commons-codec:commons-codec:1.2">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/commons-codec/commons-codec/1.2/commons-codec-1.2.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/commons-codec/commons-codec/1.2/commons-codec-1.2-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/commons-codec/commons-codec/1.2/commons-codec-1.2-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: commons-httpclient:commons-httpclient:3.1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/commons-httpclient/commons-httpclient/3.1/commons-httpclient-3.1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/commons-httpclient/commons-httpclient/3.1/commons-httpclient-3.1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/commons-httpclient/commons-httpclient/3.1/commons-httpclient-3.1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: commons-logging:commons-logging:1.0.4">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/commons-logging/commons-logging/1.0.4/commons-logging-1.0.4.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/commons-logging/commons-logging/1.0.4/commons-logging-1.0.4-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/commons-logging/commons-logging/1.0.4/commons-logging-1.0.4-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: commons-logging:commons-logging:1.1.1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/commons-logging/commons-logging/1.1.1/commons-logging-1.1.1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/commons-logging/commons-logging/1.1.1/commons-logging-1.1.1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/commons-logging/commons-logging/1.1.1/commons-logging-1.1.1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: javassist:javassist:3.6.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/javassist/javassist/3.6.0.GA/javassist-3.6.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/javassist/javassist/3.6.0.GA/javassist-3.6.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/javassist/javassist/3.6.0.GA/javassist-3.6.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: javax.activation:activation:1.1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/javax/activation/activation/1.1/activation-1.1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/javax/activation/activation/1.1/activation-1.1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/javax/activation/activation/1.1/activation-1.1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: javax.activation:activation:1.1.1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/javax/activation/activation/1.1.1/activation-1.1.1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/javax/activation/activation/1.1.1/activation-1.1.1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/javax/activation/activation/1.1.1/activation-1.1.1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: javax.annotation:jsr250-api:1.0">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/javax/annotation/jsr250-api/1.0/jsr250-api-1.0.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/javax/annotation/jsr250-api/1.0/jsr250-api-1.0-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/javax/annotation/jsr250-api/1.0/jsr250-api-1.0-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: javax.servlet:servlet-api:2.5">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/javax/servlet/servlet-api/2.5/servlet-api-2.5.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/javax/servlet/servlet-api/2.5/servlet-api-2.5-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/javax/servlet/servlet-api/2.5/servlet-api-2.5-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: jboss.jbossts:jbossjts:4.6.1.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/jboss/jbossts/jbossjts/4.6.1.GA/jbossjts-4.6.1.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/jboss/jbossts/jbossjts/4.6.1.GA/jbossjts-4.6.1.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/jboss/jbossts/jbossjts/4.6.1.GA/jbossjts-4.6.1.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/jboss/jbossts/jbossts-common/4.6.1.GA/jbossts-common-4.6.1.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/jboss/jbossts/jbossts-common/4.6.1.GA/jbossts-common-4.6.1.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/jboss/jbossts/jbossts-common/4.6.1.GA/jbossts-common-4.6.1.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: junit:junit:3.8.2">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/junit/junit/3.8.2/junit-3.8.2.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/junit/junit/3.8.2/junit-3.8.2-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/junit/junit/3.8.2/junit-3.8.2-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: junit:junit:4.1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/junit/junit/4.1/junit-4.1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/junit/junit/4.1/junit-4.1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/junit/junit/4.1/junit-4.1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: log4j:log4j:1.2.14">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/log4j/log4j/1.2.14/log4j-1.2.14.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/log4j/log4j/1.2.14/log4j-1.2.14-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/log4j/log4j/1.2.14/log4j-1.2.14-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: log4j:log4j:1.2.16">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/log4j/log4j/1.2.16/log4j-1.2.16.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/log4j/log4j/1.2.16/log4j-1.2.16-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/log4j/log4j/1.2.16/log4j-1.2.16-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: net.jcip:jcip-annotations:1.0">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/net/jcip/jcip-annotations/1.0/jcip-annotations-1.0.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/net/jcip/jcip-annotations/1.0/jcip-annotations-1.0-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/net/jcip/jcip-annotations/1.0/jcip-annotations-1.0-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.codehaus.jackson:jackson-core-asl:1.6.3">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-core-asl/1.6.3/jackson-core-asl-1.6.3.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-core-asl/1.6.3/jackson-core-asl-1.6.3-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-core-asl/1.6.3/jackson-core-asl-1.6.3-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.codehaus.jackson:jackson-jaxrs:1.6.3">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-jaxrs/1.6.3/jackson-jaxrs-1.6.3.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-jaxrs/1.6.3/jackson-jaxrs-1.6.3-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-jaxrs/1.6.3/jackson-jaxrs-1.6.3-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.codehaus.jackson:jackson-mapper-asl:1.6.3">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-mapper-asl/1.6.3/jackson-mapper-asl-1.6.3.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-mapper-asl/1.6.3/jackson-mapper-asl-1.6.3-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-mapper-asl/1.6.3/jackson-mapper-asl-1.6.3-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.codehaus.jackson:jackson-xc:1.6.3">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-xc/1.6.3/jackson-xc-1.6.3.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-xc/1.6.3/jackson-xc-1.6.3-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/codehaus/jackson/jackson-xc/1.6.3/jackson-xc-1.6.3-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/integration/jboss-transaction-spi/5.1.0.GA/jboss-transaction-spi-5.1.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/integration/jboss-transaction-spi/5.1.0.GA/jboss-transaction-spi-5.1.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/integration/jboss-transaction-spi/5.1.0.GA/jboss-transaction-spi-5.1.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jaspi-api/1.0.0.GA/jboss-jaspi-api-1.0.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jaspi-api/1.0.0.GA/jboss-jaspi-api-1.0.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jaspi-api/1.0.0.GA/jboss-jaspi-api-1.0.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jca-api/1.5.0.GA/jboss-jca-api-1.5.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jca-api/1.5.0.GA/jboss-jca-api-1.5.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jca-api/1.5.0.GA/jboss-jca-api-1.5.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jms-api/1.1.0.GA/jboss-jms-api-1.1.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jms-api/1.1.0.GA/jboss-jms-api-1.1.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-jms-api/1.1.0.GA/jboss-jms-api-1.1.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.20070913080910">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-transaction-api/1.0.1.20070913080910/jboss-transaction-api-1.0.1.20070913080910.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-transaction-api/1.0.1.20070913080910/jboss-transaction-api-1.0.1.20070913080910-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-transaction-api/1.0.1.20070913080910/jboss-transaction-api-1.0.1.20070913080910-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-transaction-api/1.0.1.GA/jboss-transaction-api-1.0.1.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-transaction-api/1.0.1.GA/jboss-transaction-api-1.0.1.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/javaee/jboss-transaction-api/1.0.1.GA/jboss-transaction-api-1.0.1.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/logging/jboss-logging-spi/2.1.0.GA/jboss-logging-spi-2.1.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/logging/jboss-logging-spi/2.1.0.GA/jboss-logging-spi-2.1.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/logging/jboss-logging-spi/2.1.0.GA/jboss-logging-spi-2.1.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/microcontainer/jboss-dependency/2.0.6.GA/jboss-dependency-2.0.6.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/microcontainer/jboss-dependency/2.0.6.GA/jboss-dependency-2.0.6.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/microcontainer/jboss-dependency/2.0.6.GA/jboss-dependency-2.0.6.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/microcontainer/jboss-kernel/2.0.6.GA/jboss-kernel-2.0.6.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/microcontainer/jboss-kernel/2.0.6.GA/jboss-kernel-2.0.6.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/microcontainer/jboss-kernel/2.0.6.GA/jboss-kernel-2.0.6.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.naming:jnpserver:5.0.3.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/naming/jnpserver/5.0.3.GA/jnpserver-5.0.3.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/naming/jnpserver/5.0.3.GA/jnpserver-5.0.3.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/naming/jnpserver/5.0.3.GA/jnpserver-5.0.3.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.netty:netty:3.2.3.Final">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/netty/netty/3.2.3.Final/netty-3.2.3.Final.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/netty/netty/3.2.3.Final/netty-3.2.3.Final-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/netty/netty/3.2.3.Final/netty-3.2.3.Final-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.resteasy:jaxrs-api:2.1.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/jaxrs-api/2.1.0.GA/jaxrs-api-2.1.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/jaxrs-api/2.1.0.GA/jaxrs-api-2.1.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/jaxrs-api/2.1.0.GA/jaxrs-api-2.1.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.resteasy:resteasy-jackson-provider:2.1.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jackson-provider/2.1.0.GA/resteasy-jackson-provider-2.1.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jackson-provider/2.1.0.GA/resteasy-jackson-provider-2.1.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jackson-provider/2.1.0.GA/resteasy-jackson-provider-2.1.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.resteasy:resteasy-jaxb-provider:2.1.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jaxb-provider/2.1.0.GA/resteasy-jaxb-provider-2.1.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jaxb-provider/2.1.0.GA/resteasy-jaxb-provider-2.1.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jaxb-provider/2.1.0.GA/resteasy-jaxb-provider-2.1.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.resteasy:resteasy-jaxrs:2.1.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jaxrs/2.1.0.GA/resteasy-jaxrs-2.1.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jaxrs/2.1.0.GA/resteasy-jaxrs-2.1.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/resteasy-jaxrs/2.1.0.GA/resteasy-jaxrs-2.1.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.resteasy:tjws:2.1.0.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/tjws/2.1.0.GA/tjws-2.1.0.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/tjws/2.1.0.GA/tjws-2.1.0.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/resteasy/tjws/2.1.0.GA/tjws-2.1.0.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/security/jboss-security-spi/2.0.3.SP1/jboss-security-spi-2.0.3.SP1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/security/jboss-security-spi/2.0.3.SP1/jboss-security-spi-2.0.3.SP1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/security/jboss-security-spi/2.0.3.SP1/jboss-security-spi-2.0.3.SP1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.security:jbosssx:2.0.3.SP1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/security/jbosssx/2.0.3.SP1/jbosssx-2.0.3.SP1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/security/jbosssx/2.0.3.SP1/jbosssx-2.0.3.SP1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/security/jbosssx/2.0.3.SP1/jbosssx-2.0.3.SP1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.spec.javax.jms:jboss-jms-api_1.1_spec:1.0.0.Beta1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/jms/jboss-jms-api_1.1_spec/1.0.0.Beta1/jboss-jms-api_1.1_spec-1.0.0.Beta1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/jms/jboss-jms-api_1.1_spec/1.0.0.Beta1/jboss-jms-api_1.1_spec-1.0.0.Beta1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/jms/jboss-jms-api_1.1_spec/1.0.0.Beta1/jboss-jms-api_1.1_spec-1.0.0.Beta1-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.spec.javax.jms:jboss-jms-api_1.1_spec:1.0.0.Final">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/jms/jboss-jms-api_1.1_spec/1.0.0.Final/jboss-jms-api_1.1_spec-1.0.0.Final.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/jms/jboss-jms-api_1.1_spec/1.0.0.Final/jboss-jms-api_1.1_spec-1.0.0.Final-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/jms/jboss-jms-api_1.1_spec/1.0.0.Final/jboss-jms-api_1.1_spec-1.0.0.Final-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss.spec.javax.transaction:jboss-transaction-api_1.1_spec:1.0.0.Final">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/transaction/jboss-transaction-api_1.1_spec/1.0.0.Final/jboss-transaction-api_1.1_spec-1.0.0.Final.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/transaction/jboss-transaction-api_1.1_spec/1.0.0.Final/jboss-transaction-api_1.1_spec-1.0.0.Final-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/spec/javax/transaction/jboss-transaction-api_1.1_spec/1.0.0.Final/jboss-transaction-api_1.1_spec-1.0.0.Final-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss:jboss-common-core:2.2.14.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-common-core/2.2.14.GA/jboss-common-core-2.2.14.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-common-core/2.2.14.GA/jboss-common-core-2.2.14.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-common-core/2.2.14.GA/jboss-common-core-2.2.14.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss:jboss-mdr:2.0.1.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-mdr/2.0.1.GA/jboss-mdr-2.0.1.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-mdr/2.0.1.GA/jboss-mdr-2.0.1.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-mdr/2.0.1.GA/jboss-mdr-2.0.1.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss:jboss-reflect:2.0.2.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-reflect/2.0.2.GA/jboss-reflect-2.0.2.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-reflect/2.0.2.GA/jboss-reflect-2.0.2.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jboss-reflect/2.0.2.GA/jboss-reflect-2.0.2.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.jboss:jbossxb:2.0.1.GA">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jbossxb/2.0.1.GA/jbossxb-2.0.1.GA.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jbossxb/2.0.1.GA/jbossxb-2.0.1.GA-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/jboss/jbossxb/2.0.1.GA/jbossxb-2.0.1.GA-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.scannotation:scannotation:1.0.2">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/scannotation/scannotation/1.0.2/scannotation-1.0.2.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/scannotation/scannotation/1.0.2/scannotation-1.0.2-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/scannotation/scannotation/1.0.2/scannotation-1.0.2-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.springframework:spring-aop:3.0.3.RELEASE">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-aop/3.0.3.RELEASE/spring-aop-3.0.3.RELEASE.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-aop/3.0.3.RELEASE/spring-aop-3.0.3.RELEASE-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-aop/3.0.3.RELEASE/spring-aop-3.0.3.RELEASE-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.springframework:spring-asm:3.0.3.RELEASE">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-asm/3.0.3.RELEASE/spring-asm-3.0.3.RELEASE.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-asm/3.0.3.RELEASE/spring-asm-3.0.3.RELEASE-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-asm/3.0.3.RELEASE/spring-asm-3.0.3.RELEASE-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.springframework:spring-beans:3.0.3.RELEASE">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-beans/3.0.3.RELEASE/spring-beans-3.0.3.RELEASE.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-beans/3.0.3.RELEASE/spring-beans-3.0.3.RELEASE-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-beans/3.0.3.RELEASE/spring-beans-3.0.3.RELEASE-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.springframework:spring-context:3.0.3.RELEASE">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-context/3.0.3.RELEASE/spring-context-3.0.3.RELEASE.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-context/3.0.3.RELEASE/spring-context-3.0.3.RELEASE-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-context/3.0.3.RELEASE/spring-context-3.0.3.RELEASE-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.springframework:spring-core:3.0.3.RELEASE">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-core/3.0.3.RELEASE/spring-core-3.0.3.RELEASE.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-core/3.0.3.RELEASE/spring-core-3.0.3.RELEASE-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-core/3.0.3.RELEASE/spring-core-3.0.3.RELEASE-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.springframework:spring-expression:3.0.3.RELEASE">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-expression/3.0.3.RELEASE/spring-expression-3.0.3.RELEASE.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-expression/3.0.3.RELEASE/spring-expression-3.0.3.RELEASE-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-expression/3.0.3.RELEASE/spring-expression-3.0.3.RELEASE-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.springframework:spring-jms:3.0.3.RELEASE">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-jms/3.0.3.RELEASE/spring-jms-3.0.3.RELEASE.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-jms/3.0.3.RELEASE/spring-jms-3.0.3.RELEASE-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-jms/3.0.3.RELEASE/spring-jms-3.0.3.RELEASE-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.springframework:spring-tx:3.0.3.RELEASE">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-tx/3.0.3.RELEASE/spring-tx-3.0.3.RELEASE.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-tx/3.0.3.RELEASE/spring-tx-3.0.3.RELEASE-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/springframework/spring-tx/3.0.3.RELEASE/spring-tx-3.0.3.RELEASE-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: org.twitter4j:twitter4j-core:2.1.2">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/org/twitter4j/twitter4j-core/2.1.2/twitter4j-core-2.1.2.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/org/twitter4j/twitter4j-core/2.1.2/twitter4j-core-2.1.2-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/org/twitter4j/twitter4j-core/2.1.2/twitter4j-core-2.1.2-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: sun-jaxb:jaxb-api:2.1.9">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/sun-jaxb/jaxb-api/2.1.9/jaxb-api-2.1.9.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/sun-jaxb/jaxb-api/2.1.9/jaxb-api-2.1.9-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/sun-jaxb/jaxb-api/2.1.9/jaxb-api-2.1.9-sources.jar!/" />
- </SOURCES>
- </library>
- <library name="Maven: wutka-dtdparser:dtdparser121:1.2.1">
- <CLASSES>
- <root url="jar://$MAVEN_REPOSITORY$/wutka-dtdparser/dtdparser121/1.2.1/dtdparser121-1.2.1.jar!/" />
- </CLASSES>
- <JAVADOC>
- <root url="jar://$MAVEN_REPOSITORY$/wutka-dtdparser/dtdparser121/1.2.1/dtdparser121-1.2.1-javadoc.jar!/" />
- </JAVADOC>
- <SOURCES>
- <root url="jar://$MAVEN_REPOSITORY$/wutka-dtdparser/dtdparser121/1.2.1/dtdparser121-1.2.1-sources.jar!/" />
- </SOURCES>
- </library>
- </component>
-</project>
-
Deleted: trunk/hornetq.iws
===================================================================
--- trunk/hornetq.iws 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/hornetq.iws 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,2449 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<project version="4">
- <component name="ChangeListManager">
- <list readonly="true" id="a2aae645-dbcd-4d6e-9c99-efa05d93589a" name="Default" comment="" />
- <list default="true" id="79260711-ec34-4afa-9678-e2f3090f876b" name="intellij" comment="">
- <change type="NEW" beforePath="" afterPath="$PROJECT_DIR$/hornetq-journal/hornetq-journal.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-bootstrap/hornetq-bootstrap.iml" afterPath="$PROJECT_DIR$/hornetq-bootstrap/hornetq-bootstrap.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-commons/hornetq-commons.iml" afterPath="$PROJECT_DIR$/hornetq-commons/hornetq-commons.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-core-client/hornetq-core-client.iml" afterPath="$PROJECT_DIR$/hornetq-core-client/hornetq-core-client.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-core/hornetq-core.iml" afterPath="$PROJECT_DIR$/hornetq-core/hornetq-core.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-jboss-as-integration/hornetq-jboss-as-integration.iml" afterPath="$PROJECT_DIR$/hornetq-jboss-as-integration/hornetq-jboss-as-integration.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-jms-client/hornetq-jms-client.iml" afterPath="$PROJECT_DIR$/hornetq-jms-client/hornetq-jms-client.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-jms/hornetq-jms.iml" afterPath="$PROJECT_DIR$/hornetq-jms/hornetq-jms.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-ra/hornetq-ra-jar/hornetq-ra.iml" afterPath="$PROJECT_DIR$/hornetq-ra/hornetq-ra-jar/hornetq-ra.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-rest/hornetq-rest-all.iml" afterPath="$PROJECT_DIR$/hornetq-rest/hornetq-rest-all.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-rest/hornetq-rest/hornetq-rest.iml" afterPath="$PROJECT_DIR$/hornetq-rest/hornetq-rest/hornetq-rest.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-service-sar/hornetq-service-sar.iml" afterPath="$PROJECT_DIR$/hornetq-service-sar/hornetq-service-sar.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-spring-integration/hornetq-spring-integration.iml" afterPath="$PROJECT_DIR$/hornetq-spring-integration/hornetq-spring-integration.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq-twitter-integration/hornetq-twitter-integration.iml" afterPath="$PROJECT_DIR$/hornetq-twitter-integration/hornetq-twitter-integration.iml" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq.ipr" afterPath="$PROJECT_DIR$/hornetq.ipr" />
- <change type="MODIFICATION" beforePath="$PROJECT_DIR$/hornetq.iws" afterPath="$PROJECT_DIR$/hornetq.iws" />
- </list>
- <ignored path=".idea/workspace.xml" />
- <ignored path="$USER_HOME_GRAILS$/" />
- <ignored path="messaging.iws" />
- <ignored path="$USER_HOME_GRIFFON$/" />
- <option name="TRACKING_ENABLED" value="true" />
- <option name="SHOW_DIALOG" value="false" />
- <option name="HIGHLIGHT_CONFLICTS" value="true" />
- <option name="HIGHLIGHT_NON_ACTIVE_CHANGELIST" value="false" />
- <option name="LAST_RESOLUTION" value="IGNORE" />
- </component>
- <component name="ChangesViewManager" flattened_view="true" show_ignored="false" />
- <component name="CoverageDataManager" choice="3" />
- <component name="CreatePatchCommitExecutor">
- <option name="PATCH_PATH" value="$PROJECT_DIR$" />
- <option name="REVERSE_PATCH" value="false" />
- </component>
- <component name="DaemonCodeAnalyzer">
- <disable_hints />
- </component>
- <component name="DebuggerManager">
- <line_breakpoints>
- <breakpoint url="file://$PROJECT_DIR$/tests/integration-tests/src/test/java/org/hornetq/tests/util/JMSClusteredTestBase.java" line="15" class="JMSClusteredTestBase.java" package="">
- <option name="ENABLED" value="true" />
- <option name="LOG_ENABLED" value="false" />
- <option name="LOG_EXPRESSION_ENABLED" value="false" />
- <option name="SUSPEND_POLICY" value="SuspendAll" />
- <option name="COUNT_FILTER_ENABLED" value="false" />
- <option name="COUNT_FILTER" value="0" />
- <option name="CONDITION_ENABLED" value="false" />
- <option name="CLASS_FILTERS_ENABLED" value="false" />
- <option name="INSTANCE_FILTERS_ENABLED" value="false" />
- <option name="CONDITION" value="" />
- <option name="LOG_MESSAGE" value="" />
- </breakpoint>
- </line_breakpoints>
- <breakpoint_any>
- <breakpoint>
- <option name="NOTIFY_CAUGHT" value="true" />
- <option name="NOTIFY_UNCAUGHT" value="true" />
- <option name="ENABLED" value="false" />
- <option name="LOG_ENABLED" value="false" />
- <option name="LOG_EXPRESSION_ENABLED" value="false" />
- <option name="SUSPEND_POLICY" value="SuspendAll" />
- <option name="COUNT_FILTER_ENABLED" value="false" />
- <option name="COUNT_FILTER" value="0" />
- <option name="CONDITION_ENABLED" value="false" />
- <option name="CLASS_FILTERS_ENABLED" value="false" />
- <option name="INSTANCE_FILTERS_ENABLED" value="false" />
- <option name="CONDITION" value="" />
- <option name="LOG_MESSAGE" value="" />
- </breakpoint>
- <breakpoint>
- <option name="NOTIFY_CAUGHT" value="true" />
- <option name="NOTIFY_UNCAUGHT" value="true" />
- <option name="ENABLED" value="false" />
- <option name="LOG_ENABLED" value="false" />
- <option name="LOG_EXPRESSION_ENABLED" value="false" />
- <option name="SUSPEND_POLICY" value="SuspendAll" />
- <option name="COUNT_FILTER_ENABLED" value="false" />
- <option name="COUNT_FILTER" value="0" />
- <option name="CONDITION_ENABLED" value="false" />
- <option name="CLASS_FILTERS_ENABLED" value="false" />
- <option name="INSTANCE_FILTERS_ENABLED" value="false" />
- <option name="CONDITION" value="" />
- <option name="LOG_MESSAGE" value="" />
- </breakpoint>
- </breakpoint_any>
- <breakpoint_rules />
- <ui_properties />
- </component>
- <component name="FavoritesManager">
- <favorites_list name="messaging" />
- </component>
- <component name="FileEditorManager">
- <leaf>
- <file leaf-file-name="pom.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/hornetq-ra/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="18" column="12" selection-start="433" selection-end="433" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="pom.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/distribution/jnp-client/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="81" column="30" selection-start="2841" selection-end="2841" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="pom.xml" pinned="false" current="true" current-in-tab="true">
- <entry file="file://$PROJECT_DIR$/distribution/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="32" column="22" selection-start="1014" selection-end="1014" vertical-scroll-proportion="1.0105263">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="dep.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/distribution/hornetq/src/main/assembly/dep.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="225" column="51" selection-start="9010" selection-end="9010" vertical-scroll-proportion="-17.8">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="pom.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/distribution/jboss-mc/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="11" column="15" selection-start="421" selection-end="429" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="pom.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/distribution/hornetq/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="13" column="5" selection-start="642" selection-end="643" vertical-scroll-proportion="-0.6">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="pom.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/hornetq-spring-integration/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="55" column="18" selection-start="2092" selection-end="2092" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="pom.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/hornetq-twitter-integration/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="25" column="19" selection-start="896" selection-end="896" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="pom.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="477" column="51" selection-start="17291" selection-end="17291" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- <file leaf-file-name="pom.xml" pinned="false" current="false" current-in-tab="false">
- <entry file="file://$PROJECT_DIR$/hornetq-core/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="8" column="43" selection-start="248" selection-end="394" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- </file>
- </leaf>
- </component>
- <component name="FindManager">
- <FindUsagesManager>
- <setting name="OPEN_NEW_TAB" value="true" />
- </FindUsagesManager>
- </component>
- <component name="HighlightingSettingsPerFile">
- <setting file="file://$PROJECT_DIR$/build-hornetq.xml" root0="SKIP_HIGHLIGHTING" />
- </component>
- <component name="IdeDocumentHistory">
- <option name="changedFiles">
- <list>
- <option value="$PROJECT_DIR$/hornetq-core-client/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-jms-client/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-ra/hornetq-ra-rar/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-service-sar/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-spring-integration/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-twitter-integration/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-core/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-jms/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-ra/hornetq-ra-jar/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-logging/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-bootstrap/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-jboss-as-integration/pom.xml" />
- <option value="$PROJECT_DIR$/hornetq-ra/pom.xml" />
- <option value="$PROJECT_DIR$/distribution/microcontainer/pom.xml" />
- <option value="$PROJECT_DIR$/distribution/hornetq/src/main/assembly/dep.xml" />
- <option value="$PROJECT_DIR$/distribution/pom.xml" />
- </list>
- </option>
- </component>
- <component name="MavenImportPreferences">
- <option name="generalSettings">
- <MavenGeneralSettings>
- <option name="mavenHome" value="$USER_HOME$/devtools/apache-maven-2.2.1" />
- </MavenGeneralSettings>
- </option>
- <option name="importingSettings">
- <MavenImportingSettings>
- <option name="importAutomatically" value="true" />
- </MavenImportingSettings>
- </option>
- </component>
- <component name="MavenProjectNavigator">
- <treeState>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="" />
- <option name="myItemType" value="org.jetbrains.idea.maven.navigator.MavenProjectsStructure$RootNode" />
- </PATH_ELEMENT>
- </PATH>
- </treeState>
- </component>
- <component name="ModuleEditorState">
- <option name="LAST_EDITED_MODULE_NAME" />
- <option name="LAST_EDITED_TAB_NAME" />
- </component>
- <component name="ProjectInspectionProfilesVisibleTreeState">
- <entry key="Project Default">
- <profile-state />
- </entry>
- </component>
- <component name="ProjectLevelVcsManager" settingsEditedManually="false">
- <OptionsSetting value="true" id="Add" />
- <OptionsSetting value="true" id="Remove" />
- <OptionsSetting value="true" id="Checkout" />
- <OptionsSetting value="true" id="Update" />
- <OptionsSetting value="true" id="Status" />
- <OptionsSetting value="true" id="Edit" />
- <ConfirmationsSetting value="0" id="Add" />
- <ConfirmationsSetting value="0" id="Remove" />
- </component>
- <component name="ProjectPane">
- <subPane>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="integration" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="integration" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="largemessage" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="integration" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="largemessage" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="mock" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="integration" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="cluster" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq-tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="tests" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="integration" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="cluster" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="distribution" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="integration" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="netty" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="integration" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="server" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="server" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="impl" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="server" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="cluster" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="server" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="cluster" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="impl" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="security" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="security" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="impl" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="remoting" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="remoting" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="impl" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="management" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="cluster" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="cluster" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="impl" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="client" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="messaging" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewModuleNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq3" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="core" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="client" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="impl" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- </subPane>
- </component>
- <component name="ProjectReloadState">
- <option name="STATE" value="0" />
- </component>
- <component name="ProjectView">
- <navigator currentView="ProjectPane" proportions="" version="1" splitterProportion="0.5">
- <flattenPackages />
- <showMembers />
- <showModules />
- <showLibraryContents />
- <hideEmptyPackages ProjectPane="false" />
- <abbreviatePackageNames />
- <autoscrollToSource />
- <autoscrollFromSource ProjectPane="true" />
- <sortByType />
- </navigator>
- <panes>
- <pane id="ProjectPane">
- <subPane>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="External Libraries" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ExternalLibrariesNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="External Libraries" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ExternalLibrariesNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.NamedLibraryElementNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss-kernel-2.0.6.GA.jar" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="External Libraries" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ExternalLibrariesNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.NamedLibraryElementNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss-kernel-2.0.6.GA.jar" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="org" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="External Libraries" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ExternalLibrariesNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.NamedLibraryElementNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss-kernel-2.0.6.GA.jar" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="org" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="kernel" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="External Libraries" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ExternalLibrariesNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.NamedLibraryElementNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss-kernel-2.0.6.GA.jar" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="org" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="kernel" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="plugins" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="External Libraries" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ExternalLibrariesNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.NamedLibraryElementNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss-kernel-2.0.6.GA.jar" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="org" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="kernel" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="plugins" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="bootstrap" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="External Libraries" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ExternalLibrariesNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.NamedLibraryElementNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss-kernel-2.0.6.GA.jar" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="org" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="kernel" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="plugins" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="bootstrap" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="basic" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="distribution" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="distribution" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jnp-client" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="distribution" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss-mc" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="distribution" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="jboss-mc" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="target" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="distribution" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="distribution" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- <PATH>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.ProjectViewProjectNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="distribution" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="hornetq" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="src" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="main" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- <PATH_ELEMENT>
- <option name="myItemId" value="assembly" />
- <option name="myItemType" value="com.intellij.ide.projectView.impl.nodes.PsiDirectoryNode" />
- </PATH_ELEMENT>
- </PATH>
- </subPane>
- </pane>
- <pane id="PackagesPane" />
- <pane id="Favorites" />
- <pane id="Scope" />
- </panes>
- </component>
- <component name="PropertiesComponent">
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatWidth1" value="287" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatWidth0" value="225" />
- <property name="project.structure.last.edited" value="Modules" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatWidth3" value="35" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatWidth2" value="247" />
- <property name="project.structure.proportion" value="0.15" />
- <property name="OverrideImplement.combined" value="true" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatOrder1" value="1" />
- <property name="options.splitter.main.proportions" value="0.3" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatOrder0" value="0" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatOrder3" value="3" />
- <property name="RunManagerConfig.showSettingsBeforeRunnig" value="false" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatOrder2" value="2" />
- <property name="recentsLimit" value="5" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeWidth2" value="200" />
- <property name="MemberChooser.sorted" value="false" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeWidth1" value="242" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatOrder4" value="4" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeWidth0" value="196" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeWidth4" value="973" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeWidth3" value="200" />
- <property name="GoToClass.includeJavaFiles" value="false" />
- <property name="GoToClass.toSaveIncludeLibraries" value="false" />
- <property name="WebServerToolWindowFactoryState" value="false" />
- <property name="MemberChooser.showClasses" value="true" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_flatWidth4" value="1017" />
- <property name="GoToClass.includeLibraries" value="false" />
- <property name="options.splitter.details.proportions" value="0.2" />
- <property name="GoToFile.includeJavaFiles" value="false" />
- <property name="options.lastSelected" value="MavenSettings" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeOrder3" value="3" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeOrder4" value="4" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeOrder1" value="1" />
- <property name="project.structure.side.proportion" value="0.2" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeOrder2" value="2" />
- <property name="MemberChooser.copyJavadoc" value="false" />
- <property name="FileHistory.org.jetbrains.idea.svn.history.SvnHistoryProvider_treeOrder0" value="0" />
- <property name="dynamic.classpath" value="false" />
- <property name="options.searchVisible" value="true" />
- </component>
- <component name="RecentsManager">
- <key name="CopyClassDialog.RECENTS_KEY">
- <recent name="org.hornetq.javaee.example" />
- <recent name="org.hornetq.jms.example" />
- </key>
- <key name="CopyFile.RECENT_KEYS">
- <recent name="$PROJECT_DIR$/distribution/microcontainer" />
- <recent name="$PROJECT_DIR$/docs/rest-manual/en" />
- <recent name="$PROJECT_DIR$/docs" />
- <recent name="$PROJECT_DIR$/distribution/hornetq" />
- <recent name="$PROJECT_DIR$/examples/src/main/assembly" />
- </key>
- <key name="MoveMembersDialog.RECENTS_KEY">
- <recent name="org.hornetq.api.core.client.HornetQClient" />
- </key>
- </component>
- <component name="RunManager" selected="JUnit.QueueTest">
- <configuration default="false" name="DiscoveryTest.testSimpleBroadcastSpecificNIC" type="JUnit" factoryName="JUnit" temporary="true">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.tests.integration.discovery.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <module name="hornetq-tests" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="PACKAGE_NAME" value="org.hornetq.tests.integration.discovery" />
- <option name="MAIN_CLASS_NAME" value="org.hornetq.tests.integration.discovery.DiscoveryTest" />
- <option name="METHOD_NAME" value="testSimpleBroadcastSpecificNIC" />
- <option name="TEST_OBJECT" value="method" />
- <option name="VM_PARAMETERS" value="-Djava.util.logging.config.file=./src/config/trunk/clustered/logging.properties -Djava.library.path=native/bin" />
- <option name="PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="HornetQMessageHandlerTest.testSelectorNotChanged" type="JUnit" factoryName="JUnit" temporary="true">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.tests.integration.ra.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <module name="hornetq-tests" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="PACKAGE_NAME" value="org.hornetq.tests.integration.ra" />
- <option name="MAIN_CLASS_NAME" value="org.hornetq.tests.integration.ra.HornetQMessageHandlerTest" />
- <option name="METHOD_NAME" value="testSelectorNotChanged" />
- <option name="TEST_OBJECT" value="method" />
- <option name="VM_PARAMETERS" value="-Djava.util.logging.config.file=./src/config/trunk/clustered/logging.properties -Djava.library.path=native/bin" />
- <option name="PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <RunnerSettings RunnerId="Debug">
- <option name="DEBUG_PORT" value="50830" />
- <option name="TRANSPORT" value="0" />
- <option name="LOCAL" value="true" />
- </RunnerSettings>
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Debug" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="HornetQMessageHandlerTest.testSelectorChanged" type="JUnit" factoryName="JUnit" temporary="true">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.tests.integration.ra.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <module name="hornetq-tests" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="PACKAGE_NAME" value="org.hornetq.tests.integration.ra" />
- <option name="MAIN_CLASS_NAME" value="org.hornetq.tests.integration.ra.HornetQMessageHandlerTest" />
- <option name="METHOD_NAME" value="testSelectorChanged" />
- <option name="TEST_OBJECT" value="method" />
- <option name="VM_PARAMETERS" value="-Djava.util.logging.config.file=./src/config/trunk/clustered/logging.properties -Djava.library.path=native/bin" />
- <option name="PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="HornetQMessageHandlerTest" type="JUnit" factoryName="JUnit" temporary="true">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.tests.integration.ra.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <module name="hornetq-tests" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="PACKAGE_NAME" value="org.hornetq.tests.integration.ra" />
- <option name="MAIN_CLASS_NAME" value="org.hornetq.tests.integration.ra.HornetQMessageHandlerTest" />
- <option name="METHOD_NAME" value="" />
- <option name="TEST_OBJECT" value="class" />
- <option name="VM_PARAMETERS" value="-Djava.util.logging.config.file=./src/config/trunk/clustered/logging.properties -Djava.library.path=native/bin" />
- <option name="PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="QueueTest" type="JUnit" factoryName="JUnit" temporary="true">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.jms.tests.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <module name="jms-tests" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="PACKAGE_NAME" value="org.hornetq.jms.tests" />
- <option name="MAIN_CLASS_NAME" value="org.hornetq.jms.tests.QueueTest" />
- <option name="METHOD_NAME" value="" />
- <option name="TEST_OBJECT" value="class" />
- <option name="VM_PARAMETERS" value="-Djava.util.logging.config.file=./src/config/trunk/clustered/logging.properties -Djava.library.path=native/bin" />
- <option name="PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="true" type="MavenRunConfiguration" factoryName="Maven">
- <MavenSettings>
- <option name="myGeneralSettings">
- <MavenGeneralSettings>
- <option name="checksumPolicy" value="FAIL" />
- <option name="failureBehavior" value="FAST" />
- <option name="localRepository" value="" />
- <option name="mavenHome" value="" />
- <option name="nonRecursive" value="false" />
- <option name="pluginUpdatePolicy" value="DO_NOT_UPDATE" />
- <option name="printErrorStackTraces" value="false" />
- <option name="snapshotUpdatePolicy" value="ALWAYS_UPDATE" />
- <option name="usePluginRegistry" value="false" />
- <option name="userSettingsFile" value="" />
- <option name="workOffline" value="false" />
- </MavenGeneralSettings>
- </option>
- <option name="myRunnerSettings">
- <MavenRunnerSettings>
- <option name="jreName" value="1.6" />
- <option name="mavenProperties">
- <map />
- </option>
- <option name="runMavenInBackground" value="true" />
- <option name="skipTests" value="false" />
- <option name="vmOptions" value="" />
- </MavenRunnerSettings>
- </option>
- <option name="myRunnerParameters">
- <MavenRunnerParameters>
- <option name="goals">
- <list />
- </option>
- <option name="profiles">
- <set />
- </option>
- <option name="workingDirPath" value="" />
- </MavenRunnerParameters>
- </option>
- </MavenSettings>
- <method>
- <option name="AntTarget" enabled="false" />
- <option name="BuildArtifacts" enabled="false" />
- <option name="Make" enabled="false" />
- <option name="Maven.BeforeRunTask" enabled="false" />
- </method>
- </configuration>
- <configuration default="true" type="Remote" factoryName="Remote">
- <option name="USE_SOCKET_TRANSPORT" value="true" />
- <option name="SERVER_MODE" value="false" />
- <option name="SHMEM_ADDRESS" value="javadebug" />
- <option name="HOST" value="localhost" />
- <option name="PORT" value="5005" />
- <method>
- <option name="AntTarget" enabled="false" />
- <option name="BuildArtifacts" enabled="false" />
- <option name="Maven.BeforeRunTask" enabled="false" />
- </method>
- </configuration>
- <configuration default="true" type="Applet" factoryName="Applet">
- <module name="" />
- <option name="MAIN_CLASS_NAME" />
- <option name="HTML_FILE_NAME" />
- <option name="HTML_USED" value="false" />
- <option name="WIDTH" value="400" />
- <option name="HEIGHT" value="300" />
- <option name="POLICY_FILE" value="$APPLICATION_HOME_DIR$/bin/appletviewer.policy" />
- <option name="VM_PARAMETERS" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" />
- <method>
- <option name="AntTarget" enabled="false" />
- <option name="BuildArtifacts" enabled="false" />
- <option name="Make" enabled="true" />
- <option name="Maven.BeforeRunTask" enabled="false" />
- </method>
- </configuration>
- <configuration default="true" type="Application" factoryName="Application">
- <extension name="coverage" enabled="false" merge="false" runner="emma" />
- <option name="MAIN_CLASS_NAME" />
- <option name="VM_PARAMETERS" />
- <option name="PROGRAM_PARAMETERS" />
- <option name="WORKING_DIRECTORY" value="$PROJECT_DIR$" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" />
- <option name="ENABLE_SWING_INSPECTOR" value="false" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <module name="" />
- <envs />
- <method>
- <option name="AntTarget" enabled="false" />
- <option name="BuildArtifacts" enabled="false" />
- <option name="Make" enabled="true" />
- <option name="Maven.BeforeRunTask" enabled="false" />
- </method>
- </configuration>
- <configuration default="true" type="JUnit" factoryName="JUnit">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma" />
- <module name="" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="PACKAGE_NAME" />
- <option name="MAIN_CLASS_NAME" value="" />
- <option name="METHOD_NAME" value="" />
- <option name="TEST_OBJECT" value="class" />
- <option name="VM_PARAMETERS" value="-Djava.util.logging.config.file=./src/config/trunk/clustered/logging.properties -Djava.library.path=native/bin" />
- <option name="PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <method>
- <option name="AntTarget" enabled="false" />
- <option name="BuildArtifacts" enabled="false" />
- <option name="Make" enabled="true" />
- <option name="Maven.BeforeRunTask" enabled="false" />
- </method>
- </configuration>
- <configuration default="false" name="EnqueueDurable" type="Application" factoryName="Application">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.test.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <option name="MAIN_CLASS_NAME" value="org.hornetq.test.EnqueueDurable" />
- <option name="VM_PARAMETERS" value="" />
- <option name="PROGRAM_PARAMETERS" value="127.0.0.1" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="ENABLE_SWING_INSPECTOR" value="false" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <module name="hornetq" />
- <envs />
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="Version" type="Application" factoryName="Application">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma" />
- <option name="MAIN_CLASS_NAME" value="org.jboss.netty.util.Version" />
- <option name="VM_PARAMETERS" value="" />
- <option name="PROGRAM_PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="ENABLE_SWING_INSPECTOR" value="false" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <module name="hornetq" />
- <envs />
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="LargeMessageTest" type="JUnit" factoryName="JUnit">
- <extension name="coverage" enabled="false" merge="false" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.tests.integration.client.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <module name="hornetq-tests" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" />
- <option name="PACKAGE_NAME" value="org.hornetq.tests.integration.client" />
- <option name="MAIN_CLASS_NAME" value="org.hornetq.tests.integration.client.LargeMessageTest" />
- <option name="METHOD_NAME" />
- <option name="TEST_OBJECT" value="class" />
- <option name="VM_PARAMETERS" />
- <option name="PARAMETERS" />
- <option name="WORKING_DIRECTORY" value="$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <RunnerSettings RunnerId="Debug">
- <option name="DEBUG_PORT" value="52003" />
- <option name="TRANSPORT" value="0" />
- <option name="LOCAL" value="true" />
- </RunnerSettings>
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Debug" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="NettyFailoverTest.test" type="JUnit" factoryName="JUnit">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.tests.integration.cluster.failover.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <module name="hornetq-tests" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="PACKAGE_NAME" value="org.hornetq.tests.integration.cluster.failover" />
- <option name="MAIN_CLASS_NAME" value="org.hornetq.tests.integration.cluster.failover.NettyFailoverTest" />
- <option name="METHOD_NAME" value="test" />
- <option name="TEST_OBJECT" value="method" />
- <option name="VM_PARAMETERS" value="-Djava.library.path=native/bin" />
- <option name="PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="GroupingFailoverReplicationTest.test" type="JUnit" factoryName="JUnit">
- <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="emma">
- <pattern>
- <option name="PATTERN" value="org.hornetq.tests.integration.cluster.failover.*" />
- <option name="ENABLED" value="true" />
- </pattern>
- </extension>
- <module name="hornetq-tests" />
- <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
- <option name="ALTERNATIVE_JRE_PATH" value="" />
- <option name="PACKAGE_NAME" value="org.hornetq.tests.integration.cluster.failover" />
- <option name="MAIN_CLASS_NAME" value="org.hornetq.tests.integration.cluster.failover.GroupingFailoverReplicationTest" />
- <option name="METHOD_NAME" value="test" />
- <option name="TEST_OBJECT" value="method" />
- <option name="VM_PARAMETERS" value="-Djava.library.path=native/bin" />
- <option name="PARAMETERS" value="" />
- <option name="WORKING_DIRECTORY" value="file://$PROJECT_DIR$" />
- <option name="ENV_VARIABLES" />
- <option name="PASS_PARENT_ENVS" value="true" />
- <option name="TEST_SEARCH_SCOPE">
- <value defaultName="moduleWithDependencies" />
- </option>
- <envs />
- <patterns />
- <RunnerSettings RunnerId="Debug">
- <option name="DEBUG_PORT" value="59963" />
- <option name="TRANSPORT" value="0" />
- <option name="LOCAL" value="true" />
- </RunnerSettings>
- <RunnerSettings RunnerId="Run" />
- <ConfigurationWrapper RunnerId="Debug" />
- <ConfigurationWrapper RunnerId="Run" />
- <method />
- </configuration>
- <configuration default="false" name="server" type="Remote" factoryName="Remote">
- <option name="USE_SOCKET_TRANSPORT" value="true" />
- <option name="SERVER_MODE" value="false" />
- <option name="SHMEM_ADDRESS" value="javadebug" />
- <option name="HOST" value="localhost" />
- <option name="PORT" value="5005" />
- <RunnerSettings RunnerId="Debug">
- <option name="DEBUG_PORT" value="5005" />
- <option name="TRANSPORT" value="0" />
- <option name="LOCAL" value="false" />
- </RunnerSettings>
- <ConfigurationWrapper RunnerId="Debug" />
- <method />
- </configuration>
- <list size="11">
- <item index="0" class="java.lang.String" itemvalue="JUnit.DiscoveryTest.testSimpleBroadcastSpecificNIC" />
- <item index="1" class="java.lang.String" itemvalue="JUnit.HornetQMessageHandlerTest.testSelectorNotChanged" />
- <item index="2" class="java.lang.String" itemvalue="JUnit.HornetQMessageHandlerTest.testSelectorChanged" />
- <item index="3" class="java.lang.String" itemvalue="JUnit.HornetQMessageHandlerTest" />
- <item index="4" class="java.lang.String" itemvalue="JUnit.QueueTest" />
- <item index="5" class="java.lang.String" itemvalue="Application.EnqueueDurable" />
- <item index="6" class="java.lang.String" itemvalue="Application.Version" />
- <item index="7" class="java.lang.String" itemvalue="JUnit.LargeMessageTest" />
- <item index="8" class="java.lang.String" itemvalue="JUnit.NettyFailoverTest.test" />
- <item index="9" class="java.lang.String" itemvalue="JUnit.GroupingFailoverReplicationTest.test" />
- <item index="10" class="java.lang.String" itemvalue="Remote.server" />
- </list>
- <configuration name="<template>" type="WebApp" default="true" selected="false">
- <Host>localhost</Host>
- <Port>5050</Port>
- </configuration>
- </component>
- <component name="ShelveChangesManager" show_recycled="false" />
- <component name="SvnConfiguration" maxAnnotateRevisions="500">
- <option name="USER" value="" />
- <option name="PASSWORD" value="" />
- <option name="mySSHConnectionTimeout" value="30000" />
- <option name="mySSHReadTimeout" value="30000" />
- <option name="LAST_MERGED_REVISION" />
- <option name="MERGE_DRY_RUN" value="false" />
- <option name="MERGE_DIFF_USE_ANCESTRY" value="true" />
- <option name="UPDATE_LOCK_ON_DEMAND" value="false" />
- <option name="IGNORE_SPACES_IN_MERGE" value="false" />
- <option name="DETECT_NESTED_COPIES" value="false" />
- <option name="CHECK_NESTED_FOR_QUICK_MERGE" value="false" />
- <option name="IGNORE_SPACES_IN_ANNOTATE" value="true" />
- <option name="SHOW_MERGE_SOURCES_IN_ANNOTATE" value="true" />
- <option name="FORCE_UPDATE" value="false" />
- <configuration useDefault="false">$USER_HOME$/.subversion</configuration>
- <myIsUseDefaultProxy>false</myIsUseDefaultProxy>
- <supportedVersion>125</supportedVersion>
- </component>
- <component name="SvnFileUrlMappingImpl">
- <option name="myMappingRoots">
- <list>
- <SvnCopyRootSimple>
- <option name="myVcsRoot" value="$PROJECT_DIR$" />
- <option name="myCopyRoot" value="$PROJECT_DIR$" />
- </SvnCopyRootSimple>
- </list>
- </option>
- <option name="myMoreRealMappingRoots">
- <list>
- <SvnCopyRootSimple>
- <option name="myVcsRoot" value="$PROJECT_DIR$" />
- <option name="myCopyRoot" value="$PROJECT_DIR$" />
- </SvnCopyRootSimple>
- </list>
- </option>
- </component>
- <component name="TaskManager">
- <task active="true" id="Default" summary="Default task">
- <option name="associatedChangelistId" value="5341122e-b51c-4e90-b798-7086790ef7e8" />
- <changelist id="a2aae645-dbcd-4d6e-9c99-efa05d93589a" name="Default" comment="" />
- <changelist id="5341122e-b51c-4e90-b798-7086790ef7e8" name="intellij" comment="" />
- <created>1260445407874</created>
- <updated>1271321502315</updated>
- </task>
- <task id="LOCAL-00001" summary="intellij">
- <created>1260445360382</created>
- <updated>1260445360382</updated>
- </task>
- <option name="localTasksCounter" value="2" />
- <servers />
- </component>
- <component name="TodoView" selected-index="0">
- <todo-panel id="selected-file">
- <are-packages-shown value="false" />
- <are-modules-shown value="false" />
- <flatten-packages value="false" />
- <is-autoscroll-to-source value="true" />
- </todo-panel>
- <todo-panel id="all">
- <are-packages-shown value="true" />
- <are-modules-shown value="false" />
- <flatten-packages value="false" />
- <is-autoscroll-to-source value="true" />
- </todo-panel>
- <todo-panel id="default-changelist">
- <are-packages-shown value="false" />
- <are-modules-shown value="false" />
- <flatten-packages value="false" />
- <is-autoscroll-to-source value="false" />
- </todo-panel>
- </component>
- <component name="ToolWindowManager">
- <frame x="0" y="25" width="1920" height="1150" extended-state="0" />
- <editor active="false" />
- <layout>
- <window_info id="Messages" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.22398414" sideWeight="0.5" order="7" side_tool="false" content_ui="tabs" />
- <window_info id="Changes" active="true" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="true" weight="0.48007968" sideWeight="0.0" order="7" side_tool="false" content_ui="tabs" />
- <window_info id="Palette" active="false" anchor="right" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="4" side_tool="false" content_ui="tabs" />
- <window_info id="TODO" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="6" side_tool="false" content_ui="tabs" />
- <window_info id="Structure" active="false" anchor="left" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.24959914" sideWeight="0.7006937" order="1" side_tool="false" content_ui="tabs" />
- <window_info id="Maven Projects" active="false" anchor="right" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="true" weight="0.0993022" sideWeight="0.5199203" order="0" side_tool="false" content_ui="tabs" />
- <window_info id="Dependency Viewer" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="7" side_tool="false" content_ui="tabs" />
- <window_info id="Project" active="false" anchor="left" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="true" weight="0.24208266" sideWeight="0.5199203" order="0" side_tool="false" content_ui="tabs" />
- <window_info id="Debug" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.16749257" sideWeight="0.0" order="3" side_tool="false" content_ui="tabs" />
- <window_info id="Run" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.23609756" sideWeight="0.5" order="2" side_tool="false" content_ui="tabs" />
- <window_info id="Version Control" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.12687312" sideWeight="0.0" order="7" side_tool="false" content_ui="tabs" />
- <window_info id="Cvs" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.25" sideWeight="0.5" order="4" side_tool="false" content_ui="tabs" />
- <window_info id="Message" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="0" side_tool="false" content_ui="tabs" />
- <window_info id="Ant Build" active="false" anchor="right" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.25" sideWeight="0.5" order="2" side_tool="false" content_ui="tabs" />
- <window_info id="Find" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="true" weight="0.22200198" sideWeight="0.5" order="1" side_tool="false" content_ui="tabs" />
- <window_info id="Dataflow to this" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="7" side_tool="false" content_ui="tabs" />
- <window_info id="IntelliHeap" active="false" anchor="bottom" auto_hide="true" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="7" side_tool="false" content_ui="tabs" />
- <window_info id="IDEtalk Messages" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="7" side_tool="false" content_ui="tabs" />
- <window_info id="IDEtalk" active="false" anchor="right" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="5" side_tool="false" content_ui="tabs" />
- <window_info id="simpleUML" active="false" anchor="left" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.33" sideWeight="0.5" order="2" side_tool="false" content_ui="tabs" />
- <window_info id="Commander" active="false" anchor="right" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.4" sideWeight="0.5" order="1" side_tool="false" content_ui="tabs" />
- <window_info id="Hierarchy" active="false" anchor="right" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.25" sideWeight="0.5" order="3" side_tool="false" content_ui="tabs" />
- <window_info id="Inspection" active="false" anchor="bottom" auto_hide="false" internal_type="DOCKED" type="DOCKED" visible="false" weight="0.4" sideWeight="0.5" order="5" side_tool="false" content_ui="tabs" />
- </layout>
- </component>
- <component name="VcsManagerConfiguration">
- <option name="OFFER_MOVE_TO_ANOTHER_CHANGELIST_ON_PARTIAL_COMMIT" value="true" />
- <option name="CHECK_CODE_SMELLS_BEFORE_PROJECT_COMMIT" value="false" />
- <option name="CHECK_NEW_TODO" value="true" />
- <option name="myTodoPanelSettings">
- <value>
- <are-packages-shown value="false" />
- <are-modules-shown value="false" />
- <flatten-packages value="false" />
- <is-autoscroll-to-source value="false" />
- </value>
- </option>
- <option name="PERFORM_UPDATE_IN_BACKGROUND" value="true" />
- <option name="PERFORM_COMMIT_IN_BACKGROUND" value="true" />
- <option name="PERFORM_EDIT_IN_BACKGROUND" value="true" />
- <option name="PERFORM_CHECKOUT_IN_BACKGROUND" value="true" />
- <option name="PERFORM_ADD_REMOVE_IN_BACKGROUND" value="true" />
- <option name="PERFORM_ROLLBACK_IN_BACKGROUND" value="false" />
- <option name="CHECK_LOCALLY_CHANGED_CONFLICTS_IN_BACKGROUND" value="true" />
- <option name="ENABLE_BACKGROUND_PROCESSES" value="false" />
- <option name="CHANGED_ON_SERVER_INTERVAL" value="60" />
- <option name="SHOW_ONLY_CHANGED_IN_SELECTION_DIFF" value="true" />
- <option name="CHECK_COMMIT_MESSAGE_SPELLING" value="true" />
- <option name="DEFAULT_PATCH_EXTENSION" value="patch" />
- <option name="FORCE_NON_EMPTY_COMMENT" value="false" />
- <option name="LAST_COMMIT_MESSAGE" value="fixed release by adding mc deps jar" />
- <option name="MAKE_NEW_CHANGELIST_ACTIVE" value="true" />
- <option name="OPTIMIZE_IMPORTS_BEFORE_PROJECT_COMMIT" value="false" />
- <option name="CHECK_FILES_UP_TO_DATE_BEFORE_COMMIT" value="false" />
- <option name="REFORMAT_BEFORE_PROJECT_COMMIT" value="false" />
- <option name="REFORMAT_BEFORE_FILE_COMMIT" value="false" />
- <option name="FILE_HISTORY_DIALOG_COMMENTS_SPLITTER_PROPORTION" value="0.8" />
- <option name="FILE_HISTORY_DIALOG_SPLITTER_PROPORTION" value="0.5" />
- <option name="ACTIVE_VCS_NAME" />
- <option name="UPDATE_GROUP_BY_PACKAGES" value="false" />
- <option name="UPDATE_GROUP_BY_CHANGELIST" value="false" />
- <option name="SHOW_FILE_HISTORY_AS_TREE" value="false" />
- <option name="FILE_HISTORY_SPLITTER_PROPORTION" value="0.6" />
- <MESSAGE value="moved examples back " />
- <MESSAGE value="cleaned up examples build" />
- <MESSAGE value="added dependency for jnpserver and jms api" />
- <MESSAGE value="added dependency for jnp client jar and removed version extensions from jars" />
- <MESSAGE value="moved the actual hornetq distro module" />
- <MESSAGE value="tweaks to fix build" />
- <MESSAGE value="intellij stuff" />
- <MESSAGE value="fixed examples" />
- <MESSAGE value="moved binaries" />
- <MESSAGE value="added javadoc to core" />
- <MESSAGE value="include javadoc in distro" />
- <MESSAGE value="included user manual and quickstart guide in distro" />
- <MESSAGE value="added better control over running tests" />
- <MESSAGE value="add validation for core configuration" />
- <MESSAGE value="added validation for jms config" />
- <MESSAGE value="added validation for jms users config" />
- <MESSAGE value="added rest jar and integrated docs" />
- <MESSAGE value="added release profile" />
- <MESSAGE value="added test profile" />
- <MESSAGE value="updated test profile" />
- <MESSAGE value="intellij file" />
- <MESSAGE value="dont deploy tests and docs and distribution" />
- <MESSAGE value="added correct snapshot repos" />
- <MESSAGE value="tidied up poms" />
- <MESSAGE value="fixed release by adding mc deps jar" />
- </component>
- <component name="XDebuggerManager">
- <breakpoint-manager />
- </component>
- <component name="antWorkspaceConfiguration">
- <option name="IS_AUTOSCROLL_TO_SOURCE" value="false" />
- <option name="FILTER_TARGETS" value="false" />
- <buildFile url="file://$PROJECT_DIR$/build-hornetq.xml">
- <antCommandLine value="" />
- <runInBackground value="true" />
- <targetFilters>
- <filter targetName="jar-transports" isVisible="false" />
- <filter targetName="runClusteredServer" isVisible="false" />
- <filter targetName="concurrent-tests" isVisible="false" />
- <filter targetName="performance-tests" isVisible="false" />
- <filter targetName="jar-bootstrap" isVisible="false" />
- <filter targetName="javadoc" isVisible="false" />
- <filter targetName="compile-transports" isVisible="false" />
- <filter targetName="tests-validate-error" isVisible="false" />
- <filter targetName="source-distro" isVisible="false" />
- <filter targetName="runServer" isVisible="false" />
- <filter targetName="compile-logging" isVisible="false" />
- <filter targetName="jar" isVisible="false" />
- <filter targetName="jar-logging" isVisible="false" />
- <filter targetName="unit-tests" isVisible="false" />
- <filter targetName="compile-bootstrap" isVisible="false" />
- <filter targetName="jar-mc" isVisible="false" />
- <filter targetName="stress-tests" isVisible="false" />
- <filter targetName="debugServer" isVisible="false" />
- <filter targetName="all-tests" isVisible="false" />
- <filter targetName="jar-jnp-client" isVisible="false" />
- <filter targetName="init" isVisible="false" />
- <filter targetName="-validate-configuration" isVisible="false" />
- <filter targetName="compile-unit-tests" isVisible="false" />
- <filter targetName="jar-ra" isVisible="false" />
- <filter targetName="tests-onerror" isVisible="false" />
- <filter targetName="compile-jms" isVisible="false" />
- <filter targetName="compile-joram-tests" isVisible="false" />
- <filter targetName="joram-tests" isVisible="false" />
- <filter targetName="compile-reports" isVisible="false" />
- <filter targetName="jar-core" isVisible="false" />
- <filter targetName="createthirdparty" isVisible="false" />
- <filter targetName="compile-jboss-integration" isVisible="false" />
- <filter targetName="compile-ra" isVisible="false" />
- <filter targetName="findbugs" isVisible="false" />
- <filter targetName="hudson-tests" isVisible="false" />
- <filter targetName="jar-jms-client" isVisible="false" />
- <filter targetName="build-native" isVisible="false" />
- <filter targetName="jar-jms" isVisible="false" />
- <filter targetName="emma" isVisible="false" />
- <filter targetName="artifacts" isVisible="false" />
- <filter targetName="check.inhibit.downloads" isVisible="false" />
- <filter targetName="jms-tests" isVisible="false" />
- <filter targetName="clean" isVisible="false" />
- <filter targetName="tests" isVisible="false" />
- <filter targetName="compile" isVisible="false" />
- <filter targetName="compile-core" isVisible="false" />
- <filter targetName="jar-resources" isVisible="false" />
- <filter targetName="bin-distro" isVisible="false" />
- <filter targetName="validate-configuration" isVisible="false" />
- <filter targetName="userdoc" isVisible="false" />
- <filter targetName="compile-jms-tests" isVisible="false" />
- <filter targetName="jar-jboss-integration" isVisible="false" />
- <filter targetName="distribution-tests" isVisible="false" />
- <filter targetName="timing-tests" isVisible="false" />
- <filter targetName="artifact" isVisible="false" />
- <filter targetName="dist-doc" isVisible="false" />
- <filter targetName="jar-core-client" isVisible="false" />
- <filter targetName="integration-tests" isVisible="false" />
- <filter targetName="failover-tests" isVisible="false" />
- </targetFilters>
- <treeView value="true" />
- <verbose value="true" />
- <viewClosedWhenNoErrors value="false" />
- </buildFile>
- </component>
- <component name="editorHistoryManager">
- <entry file="file://$PROJECT_DIR$/hornetq-bootstrap/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="32" column="19" selection-start="1143" selection-end="1143" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/hornetq-jboss-as-integration/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="42" column="0" selection-start="1474" selection-end="1474" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/hornetq-ra/hornetq-ra-jar/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="33" column="0" selection-start="1166" selection-end="1166" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/hornetq-ra/hornetq-ra-rar/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="63" column="24" selection-start="2396" selection-end="2396" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/hornetq-service-sar/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="32" column="0" selection-start="1138" selection-end="1138" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/hornetq-spring-integration/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="55" column="18" selection-start="2092" selection-end="2092" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/hornetq-twitter-integration/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="25" column="19" selection-start="896" selection-end="896" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="477" column="51" selection-start="17291" selection-end="17291" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/hornetq-core/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="8" column="43" selection-start="248" selection-end="394" vertical-scroll-proportion="0.0" />
- </provider>
- </entry>
- <entry file="jar://$MAVEN_REPOSITORY$/org/jboss/microcontainer/jboss-kernel/2.0.6.GA/jboss-kernel-2.0.6.GA.jar!/org/jboss/kernel/plugins/bootstrap/basic/BasicBootstrap.class">
- <provider selected="true" editor-type-id="text-editor">
- <state line="10" column="157" selection-start="421" selection-end="421" vertical-scroll-proportion="0.26642984">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/hornetq-ra/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="18" column="12" selection-start="433" selection-end="433" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/distribution/jnp-client/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="81" column="30" selection-start="2841" selection-end="2841" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/distribution/hornetq/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="13" column="5" selection-start="642" selection-end="643" vertical-scroll-proportion="-0.6">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/distribution/jboss-mc/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="11" column="15" selection-start="421" selection-end="429" vertical-scroll-proportion="0.0">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/distribution/hornetq/src/main/assembly/dep.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="225" column="51" selection-start="9010" selection-end="9010" vertical-scroll-proportion="-17.8">
- <folding />
- </state>
- </provider>
- </entry>
- <entry file="file://$PROJECT_DIR$/distribution/pom.xml">
- <provider selected="true" editor-type-id="text-editor">
- <state line="32" column="22" selection-start="1014" selection-end="1014" vertical-scroll-proportion="1.0105263">
- <folding />
- </state>
- </provider>
- </entry>
- </component>
- <component name="masterDetails">
- <states>
- <state key="Copyright.UI">
- <settings>
- <splitter-proportions />
- </settings>
- </state>
- <state key="GlobalLibrariesConfigurable.UI">
- <settings>
- <splitter-proportions>
- <option name="proportions">
- <list>
- <option value="0.2" />
- </list>
- </option>
- </splitter-proportions>
- </settings>
- </state>
- <state key="ScopeChooserConfigurable.UI">
- <settings>
- <splitter-proportions />
- </settings>
- </state>
- </states>
- </component>
- <component name="simpleUML.UMLToolWindowPlugin">
- <General>
- <option name="birdViewUpdateDelay" value="2000" />
- <option name="defaultFileLocation" value="file://$PROJECT_DIR$/.." />
- </General>
- <Classdiagram>
- <option name="diagramTitleFont" value="SansSerif,1,12" />
- <option name="diagramFont" value="SansSerif,0,10" />
- <option name="defaultFieldsExpanded" value="false" />
- <option name="defaultContructorsExpanded" value="false" />
- <option name="defaultMethodsExpanded" value="false" />
- <option name="showParameters" value="true" />
- <option name="showTooltip" value="true" />
- <option name="showReturnValues" value="true" />
- <option name="longModifier" value="true" />
- <option name="implementsBehaviour" value="1" />
- <option name="extendsBehaviour" value="1" />
- <option name="compartmentBehaviour" value="1" />
- <option name="interfaceBackgroundColor" value="-6494306" />
- <option name="abstractClassBackgroundColor" value="-1580132" />
- <option name="classBackgroundColor" value="-6508057" />
- <option name="diagramBackgroundColor" value="-1" />
- <option name="useAntialiasedConnectors" value="true" />
- <option name="quickSourceLinkColor" value="-16776961" />
- <option name="quickDiagramLinkColor" value="-8454144" />
- <option name="drawDecorations" value="false" />
- <option name="hideFieldList" value="" />
- <option name="showFieldList" value="" />
- <option name="hideConstructorList" value="" />
- <option name="showConstructorList" value="" />
- <option name="hideMethodList" value="" />
- <option name="showMethodList" value="" />
- <option name="minimumFigureSize" value="0,0" />
- </Classdiagram>
- <Dependencydiagram>
- <option name="diagramTitleFont" value="SansSerif,1,12" />
- <option name="diagramFont" value="SansSerif,0,10" />
- <option name="diagramBackgroundColor" value="-1" />
- <option name="useAntialiasedConnectors" value="true" />
- <option name="packageNameCompressionLevel" value="0" />
- </Dependencydiagram>
- <Packagediagram>
- <option name="diagramTitleFont" value="SansSerif,0,12" />
- <option name="diagramFont" value="SansSerif,0,10" />
- <option name="packageBackgroundColor" value="-4144960" />
- <option name="diagramBackgroundColor" value="-1" />
- <option name="useAntialiasedConnectors" value="true" />
- <option name="packageNameCompressionLevel" value="2" />
- </Packagediagram>
- </component>
-</project>
-
Deleted: trunk/tests/concurrent-tests/concurrent-tests.iml
===================================================================
--- trunk/tests/concurrent-tests/concurrent-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/concurrent-tests/concurrent-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,61 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="unit-tests" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- <orderEntry type="module" module-name="integration-tests" />
- <orderEntry type="module" module-name="jms-tests" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-logging:commons-logging:1.1.0.jboss" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.14" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-logging" />
- <orderEntry type="module" module-name="hornetq-twitter-integration" />
- <orderEntry type="library" name="Maven: org.twitter4j:twitter4j-core:2.1.2" level="project" />
- <orderEntry type="module" module-name="hornetq-spring-integration" />
- <orderEntry type="library" name="Maven: org.springframework:spring-core:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-asm:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: commons-logging:commons-logging:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-beans:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-context:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-aop:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: aopalliance:aopalliance:1.0" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-expression:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-jms:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-tx:3.0.3.RELEASE" level="project" />
- </component>
-</module>
-
Deleted: trunk/tests/hornetq-tests-pom.iml
===================================================================
--- trunk/tests/hornetq-tests-pom.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/hornetq-tests-pom.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,13 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_5" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- </component>
-</module>
-
Deleted: trunk/tests/integration-tests/integration-tests.iml
===================================================================
--- trunk/tests/integration-tests/integration-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/integration-tests/integration-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,67 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/target/generated-sources/test-annotations" isTestSource="true" />
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target/apidocs" />
- <excludeFolder url="file://$MODULE_DIR$/target/classes" />
- <excludeFolder url="file://$MODULE_DIR$/target/javadoc-bundle-options" />
- <excludeFolder url="file://$MODULE_DIR$/target/maven-archiver" />
- <excludeFolder url="file://$MODULE_DIR$/target/site" />
- <excludeFolder url="file://$MODULE_DIR$/target/test-classes" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="jms-tests" />
- <orderEntry type="module" module-name="unit-tests" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-logging:commons-logging:1.1.0.jboss" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.14" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-logging" />
- <orderEntry type="module" module-name="hornetq-twitter-integration" />
- <orderEntry type="library" name="Maven: org.twitter4j:twitter4j-core:2.1.2" level="project" />
- <orderEntry type="module" module-name="hornetq-spring-integration" />
- <orderEntry type="library" name="Maven: org.springframework:spring-core:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-asm:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: commons-logging:commons-logging:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-beans:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-context:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-aop:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: aopalliance:aopalliance:1.0" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-expression:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-jms:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-tx:3.0.3.RELEASE" level="project" />
- </component>
-</module>
-
Deleted: trunk/tests/jms-tests/jms-tests.iml
===================================================================
--- trunk/tests/jms-tests/jms-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/jms-tests/jms-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,46 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <sourceFolder url="file://$MODULE_DIR$/config" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="unit-tests" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-logging:commons-logging:1.1.0.jboss" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.14" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA" level="project" />
- </component>
-</module>
-
Deleted: trunk/tests/joram-tests/joram-tests.iml
===================================================================
--- trunk/tests/joram-tests/joram-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/joram-tests/joram-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,62 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <sourceFolder url="file://$MODULE_DIR$/config" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="unit-tests" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- <orderEntry type="module" module-name="integration-tests" />
- <orderEntry type="module" module-name="jms-tests" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-logging:commons-logging:1.1.0.jboss" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.14" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-logging" />
- <orderEntry type="module" module-name="hornetq-twitter-integration" />
- <orderEntry type="library" name="Maven: org.twitter4j:twitter4j-core:2.1.2" level="project" />
- <orderEntry type="module" module-name="hornetq-spring-integration" />
- <orderEntry type="library" name="Maven: org.springframework:spring-core:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-asm:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: commons-logging:commons-logging:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-beans:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-context:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-aop:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: aopalliance:aopalliance:1.0" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-expression:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-jms:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-tx:3.0.3.RELEASE" level="project" />
- </component>
-</module>
-
Deleted: trunk/tests/performance-tests/performance-tests.iml
===================================================================
--- trunk/tests/performance-tests/performance-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/performance-tests/performance-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,61 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="unit-tests" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- <orderEntry type="module" module-name="integration-tests" />
- <orderEntry type="module" module-name="jms-tests" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-logging:commons-logging:1.1.0.jboss" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.14" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-logging" />
- <orderEntry type="module" module-name="hornetq-twitter-integration" />
- <orderEntry type="library" name="Maven: org.twitter4j:twitter4j-core:2.1.2" level="project" />
- <orderEntry type="module" module-name="hornetq-spring-integration" />
- <orderEntry type="library" name="Maven: org.springframework:spring-core:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-asm:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: commons-logging:commons-logging:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-beans:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-context:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-aop:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: aopalliance:aopalliance:1.0" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-expression:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-jms:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-tx:3.0.3.RELEASE" level="project" />
- </component>
-</module>
-
Deleted: trunk/tests/soak-tests/soak-tests.iml
===================================================================
--- trunk/tests/soak-tests/soak-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/soak-tests/soak-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,61 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="unit-tests" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- <orderEntry type="module" module-name="integration-tests" />
- <orderEntry type="module" module-name="jms-tests" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-logging:commons-logging:1.1.0.jboss" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.14" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-logging" />
- <orderEntry type="module" module-name="hornetq-twitter-integration" />
- <orderEntry type="library" name="Maven: org.twitter4j:twitter4j-core:2.1.2" level="project" />
- <orderEntry type="module" module-name="hornetq-spring-integration" />
- <orderEntry type="library" name="Maven: org.springframework:spring-core:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-asm:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: commons-logging:commons-logging:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-beans:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-context:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-aop:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: aopalliance:aopalliance:1.0" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-expression:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-jms:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-tx:3.0.3.RELEASE" level="project" />
- </component>
-</module>
-
Deleted: trunk/tests/stress-tests/stress-tests.iml
===================================================================
--- trunk/tests/stress-tests/stress-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/stress-tests/stress-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,61 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="unit-tests" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- <orderEntry type="module" module-name="integration-tests" />
- <orderEntry type="module" module-name="jms-tests" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-logging:commons-logging:1.1.0.jboss" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.14" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-logging" />
- <orderEntry type="module" module-name="hornetq-twitter-integration" />
- <orderEntry type="library" name="Maven: org.twitter4j:twitter4j-core:2.1.2" level="project" />
- <orderEntry type="module" module-name="hornetq-spring-integration" />
- <orderEntry type="library" name="Maven: org.springframework:spring-core:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-asm:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: commons-logging:commons-logging:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-beans:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-context:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-aop:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: aopalliance:aopalliance:1.0" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-expression:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-jms:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-tx:3.0.3.RELEASE" level="project" />
- </component>
-</module>
-
Deleted: trunk/tests/timing-tests/timing-tests.iml
===================================================================
--- trunk/tests/timing-tests/timing-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/timing-tests/timing-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,61 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="unit-tests" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- <orderEntry type="module" module-name="integration-tests" />
- <orderEntry type="module" module-name="jms-tests" />
- <orderEntry type="library" name="Maven: org.jboss.naming:jnpserver:5.0.3.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossts-common:4.6.1.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-logging:commons-logging:1.1.0.jboss" level="project" />
- <orderEntry type="library" name="Maven: log4j:log4j:1.2.14" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.integration:jboss-transaction-spi:5.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jaspi-api:1.0.0.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-logging" />
- <orderEntry type="module" module-name="hornetq-twitter-integration" />
- <orderEntry type="library" name="Maven: org.twitter4j:twitter4j-core:2.1.2" level="project" />
- <orderEntry type="module" module-name="hornetq-spring-integration" />
- <orderEntry type="library" name="Maven: org.springframework:spring-core:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-asm:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: commons-logging:commons-logging:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-beans:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-context:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-aop:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: aopalliance:aopalliance:1.0" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-expression:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-jms:3.0.3.RELEASE" level="project" />
- <orderEntry type="library" name="Maven: org.springframework:spring-tx:3.0.3.RELEASE" level="project" />
- </component>
-</module>
-
Deleted: trunk/tests/unit-tests/unit-tests.iml
===================================================================
--- trunk/tests/unit-tests/unit-tests.iml 2012-02-14 16:29:05 UTC (rev 12115)
+++ trunk/tests/unit-tests/unit-tests.iml 2012-02-15 11:42:44 UTC (rev 12116)
@@ -1,39 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<module type="JAVA_MODULE" version="4">
- <component name="NewModuleRootManager" LANGUAGE_LEVEL="JDK_1_6" inherit-compiler-output="false">
- <output url="file://$MODULE_DIR$/target/classes" />
- <output-test url="file://$MODULE_DIR$/target/test-classes" />
- <content url="file://$MODULE_DIR$">
- <sourceFolder url="file://$MODULE_DIR$/src/main/java" isTestSource="false" />
- <sourceFolder url="file://$MODULE_DIR$/src/test/java" isTestSource="true" />
- <excludeFolder url="file://$MODULE_DIR$/target" />
- </content>
- <orderEntry type="inheritedJdk" />
- <orderEntry type="sourceFolder" forTests="false" />
- <orderEntry type="module" module-name="hornetq-core" />
- <orderEntry type="library" name="Maven: org.jboss.netty:netty:3.2.3.Final" level="project" />
- <orderEntry type="module" module-name="hornetq-jms" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jms-api:1.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-transaction-api:1.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: jboss.jbossts:jbossjts:4.6.1.GA" level="project" />
- <orderEntry type="module" module-name="hornetq-ra" />
- <orderEntry type="module" module-name="hornetq-bootstrap" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-kernel:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.microcontainer:jboss-dependency:2.0.6.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jbossxb:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.logging:jboss-logging-spi:2.1.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-common-core:2.2.14.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-reflect:2.0.2.GA" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xml-apis:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: apache-xerces:xercesImpl:2.9.1" level="project" />
- <orderEntry type="library" name="Maven: wutka-dtdparser:dtdparser121:1.2.1" level="project" />
- <orderEntry type="library" name="Maven: javax.activation:activation:1.1.1" level="project" />
- <orderEntry type="library" name="Maven: sun-jaxb:jaxb-api:2.1.9" level="project" />
- <orderEntry type="library" name="Maven: org.jboss:jboss-mdr:2.0.1.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.javaee:jboss-jca-api:1.5.0.GA" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jboss-security-spi:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: org.jboss.security:jbosssx:2.0.3.SP1" level="project" />
- <orderEntry type="library" name="Maven: junit:junit:3.8.2" level="project" />
- </component>
-</module>
-
12 years, 10 months