Search in sources :

Example 26 with MessageSelector

use of com.swiftmq.ms.MessageSelector in project swiftmq-ce by iitsoftware.

the class BrowserManager method createBrowser.

public void createBrowser(CreateBrowserRequest request) {
    CreateBrowserReply reply = (CreateBrowserReply) request.createReply();
    QueueImpl queue = request.getQueue();
    String messageSelector = request.getMessageSelector();
    MessageSelector msel = null;
    String queueName = null;
    try {
        queueName = queue.getQueueName();
    } catch (JMSException ignored) {
    }
    try {
        if (messageSelector != null) {
            msel = new MessageSelector(messageSelector);
            msel.compile();
        }
        if (!ctx.queueManager.isQueueRunning(queueName)) {
            ctx.logSwiftlet.logWarning("sys$jms", ctx.tracePrefix + "/" + toString() + ": Invalid destination: " + queueName);
            if (ctx.traceSpace.enabled)
                ctx.traceSpace.trace("sys$jms", ctx.tracePrefix + "/" + toString() + ": Invalid destination: " + queue);
            reply.setOk(false);
            reply.setException(new InvalidDestinationException("Invalid destination: " + queueName));
        } else {
            if (ctx.traceSpace.enabled)
                ctx.traceSpace.trace("sys$jms", ctx.tracePrefix + "/" + toString() + ": Creating browser with selector: " + msel);
            com.swiftmq.swiftlet.queue.QueueBrowser queueBrowser = ctx.queueManager.createQueueBrowser(queueName, ctx.activeLogin, msel);
            int idx = ArrayListTool.setFirstFreeOrExpand(queueBrowsers, queueBrowser);
            reply.setOk(true);
            reply.setQueueBrowserId(idx);
            if (browserEntityList != null) {
                Entity browserEntity = browserEntityList.createEntity();
                browserEntity.setName(queueName + "-" + idx);
                browserEntity.setDynamicObject(queueBrowser);
                browserEntity.createCommands();
                Property prop = browserEntity.getProperty("queue");
                prop.setValue(queueName);
                prop.setReadOnly(true);
                prop = browserEntity.getProperty("selector");
                if (msel != null) {
                    prop.setValue(msel.getConditionString());
                }
                prop.setReadOnly(true);
                browserEntityList.addEntity(browserEntity);
            }
        }
    } catch (InvalidSelectorException e) {
        ctx.logSwiftlet.logWarning("sys$jms", ctx.tracePrefix + "/" + toString() + ": CreateBrowser has invalid Selector: " + e);
        if (ctx.traceSpace.enabled)
            ctx.traceSpace.trace("sys$jms", ctx.tracePrefix + "/" + toString() + ": CreateBrowser has invalid Selector: " + e);
        reply.setOk(false);
        reply.setException(e);
    } catch (Exception e) {
        ctx.logSwiftlet.logWarning("sys$jms", ctx.tracePrefix + "/" + toString() + ": Exception during createQueueBrowser: " + e);
        if (ctx.traceSpace.enabled)
            ctx.traceSpace.trace("sys$jms", ctx.tracePrefix + "/" + toString() + ": Exception during createQueueBrowser: " + e);
        reply.setOk(false);
        reply.setException(e);
    }
    reply.send();
}
Also used : Entity(com.swiftmq.mgmt.Entity) InvalidSelectorException(javax.jms.InvalidSelectorException) InvalidDestinationException(javax.jms.InvalidDestinationException) JMSException(javax.jms.JMSException) QueueImpl(com.swiftmq.jms.QueueImpl) InvalidSelectorException(javax.jms.InvalidSelectorException) InvalidDestinationException(javax.jms.InvalidDestinationException) JMSException(javax.jms.JMSException) MessageSelector(com.swiftmq.ms.MessageSelector) Property(com.swiftmq.mgmt.Property)

Example 27 with MessageSelector

use of com.swiftmq.ms.MessageSelector in project swiftmq-ce by iitsoftware.

the class BrowserManager method createBrowser.

public void createBrowser(CreateBrowserRequest request) {
    CreateBrowserReply reply = (CreateBrowserReply) request.createReply();
    QueueImpl queue = request.getQueue();
    String messageSelector = request.getMessageSelector();
    MessageSelector msel = null;
    String queueName = null;
    try {
        queueName = queue.getQueueName();
    } catch (JMSException ignored) {
    }
    try {
        if (messageSelector != null) {
            msel = new MessageSelector(messageSelector);
            msel.compile();
        }
        if (!ctx.queueManager.isQueueRunning(queueName)) {
            ctx.logSwiftlet.logWarning("sys$jms", ctx.tracePrefix + "/" + toString() + ": Invalid destination: " + queueName);
            if (ctx.traceSpace.enabled)
                ctx.traceSpace.trace("sys$jms", ctx.tracePrefix + "/" + toString() + ": Invalid destination: " + queue);
            reply.setOk(false);
            reply.setException(new InvalidDestinationException("Invalid destination: " + queueName));
        } else {
            if (ctx.traceSpace.enabled)
                ctx.traceSpace.trace("sys$jms", ctx.tracePrefix + "/" + toString() + ": Creating browser with selector: " + msel);
            com.swiftmq.swiftlet.queue.QueueBrowser queueBrowser = ctx.queueManager.createQueueBrowser(queueName, ctx.activeLogin, msel);
            int idx = ArrayListTool.setFirstFreeOrExpand(queueBrowsers, queueBrowser);
            reply.setOk(true);
            reply.setQueueBrowserId(idx);
            if (browserEntityList != null) {
                Entity browserEntity = browserEntityList.createEntity();
                browserEntity.setName(queueName + "-" + idx);
                browserEntity.setDynamicObject(queueBrowser);
                browserEntity.createCommands();
                Property prop = browserEntity.getProperty("queue");
                prop.setValue(queueName);
                prop.setReadOnly(true);
                prop = browserEntity.getProperty("selector");
                if (msel != null) {
                    prop.setValue(msel.getConditionString());
                }
                prop.setReadOnly(true);
                browserEntityList.addEntity(browserEntity);
            }
        }
    } catch (InvalidSelectorException e) {
        ctx.logSwiftlet.logWarning("sys$jms", ctx.tracePrefix + "/" + toString() + ": CreateBrowser has invalid Selector: " + e);
        if (ctx.traceSpace.enabled)
            ctx.traceSpace.trace("sys$jms", ctx.tracePrefix + "/" + toString() + ": CreateBrowser has invalid Selector: " + e);
        reply.setOk(false);
        reply.setException(e);
    } catch (Exception e) {
        ctx.logSwiftlet.logWarning("sys$jms", ctx.tracePrefix + "/" + toString() + ": Exception during createQueueBrowser: " + e);
        if (ctx.traceSpace.enabled)
            ctx.traceSpace.trace("sys$jms", ctx.tracePrefix + "/" + toString() + ": Exception during createQueueBrowser: " + e);
        reply.setOk(false);
        reply.setException(e);
    }
    reply.send();
}
Also used : Entity(com.swiftmq.mgmt.Entity) InvalidSelectorException(javax.jms.InvalidSelectorException) InvalidDestinationException(javax.jms.InvalidDestinationException) JMSException(javax.jms.JMSException) QueueImpl(com.swiftmq.jms.QueueImpl) InvalidSelectorException(javax.jms.InvalidSelectorException) InvalidDestinationException(javax.jms.InvalidDestinationException) JMSException(javax.jms.JMSException) MessageSelector(com.swiftmq.ms.MessageSelector) Property(com.swiftmq.mgmt.Property)

Example 28 with MessageSelector

use of com.swiftmq.ms.MessageSelector in project swiftmq-ce by iitsoftware.

the class CompositeQueue method createPushTransaction.

public Object createPushTransaction() throws QueueException {
    if (ctx.queueSpace.enabled)
        ctx.queueSpace.trace(getQueueName(), "createPushTransaction ...");
    CompositeTransactionId cTxId = new CompositeTransactionId();
    Map m = queueBindings.getEntities();
    if (m != null && m.size() > 0) {
        for (Iterator iter = m.entrySet().iterator(); iter.hasNext(); ) {
            Entity entity = (Entity) ((Map.Entry) iter.next()).getValue();
            AbstractQueue queue = ctx.queueManager.getQueueForInternalUse(entity.getName(), true);
            if (queue == null) {
                ctx.logSwiftlet.logError(ctx.queueManager.getName(), "Composite Queue '" + getQueueName() + "': Queue Binding, queue '" + entity.getName() + "' not found!");
                if (ctx.queueSpace.enabled)
                    ctx.queueSpace.trace(getQueueName(), "Queue Binding, queue '" + entity.getName() + "' not found!");
            } else {
                cTxId.add(new CompositeTransactionIdEntry(true, queue, queue.createPushTransaction(), (MessageSelector) entity.getUserObject(), ((Boolean) entity.getProperty("generate-new-message-id").getValue()).booleanValue(), ((Boolean) entity.getProperty("change-destination").getValue()).booleanValue(), ((Boolean) entity.getProperty("default-delivery").getValue()).booleanValue(), entity.getName()));
            }
        }
    }
    m = topicBindings.getEntities();
    if (m != null && m.size() > 0) {
        for (Iterator iter = m.entrySet().iterator(); iter.hasNext(); ) {
            Entity entity = (Entity) ((Map.Entry) iter.next()).getValue();
            String queueName = ctx.topicManager.getQueueForTopic(entity.getName());
            AbstractQueue queue = ctx.queueManager.getQueueForInternalUse(queueName, true);
            if (queue == null) {
                ctx.logSwiftlet.logError(ctx.queueManager.getName(), "Composite Queue '" + getQueueName() + "': Topic Binding, topic '" + entity.getName() + "' not found!");
                if (ctx.queueSpace.enabled)
                    ctx.queueSpace.trace(getQueueName(), "Topic Binding, topic '" + entity.getName() + "' not found!");
            } else {
                cTxId.add(new CompositeTransactionIdEntry(false, queue, queue.createPushTransaction(), (MessageSelector) entity.getUserObject(), ((Boolean) entity.getProperty("generate-new-message-id").getValue()).booleanValue(), false, ((Boolean) entity.getProperty("default-delivery").getValue()).booleanValue(), entity.getName()));
            }
        }
    }
    if (ctx.queueSpace.enabled)
        ctx.queueSpace.trace(getQueueName(), "createPushTransaction done, cTxId=" + cTxId);
    return cTxId;
}
Also used : AbstractQueue(com.swiftmq.swiftlet.queue.AbstractQueue) Iterator(java.util.Iterator) MessageSelector(com.swiftmq.ms.MessageSelector) Map(java.util.Map)

Example 29 with MessageSelector

use of com.swiftmq.ms.MessageSelector in project swiftmq-ce by iitsoftware.

the class TopicManagerImpl method startup.

protected void startup(Configuration config) throws SwiftletException {
    this.config = config;
    root = config;
    ctx = new TopicManagerContext();
    ctx.topicManager = this;
    ctx.traceSwiftlet = (TraceSwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$trace");
    ctx.traceSpace = ctx.traceSwiftlet.getTraceSpace(TraceSwiftlet.SPACE_KERNEL);
    ctx.logSwiftlet = (LogSwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$log");
    ctx.storeSwiftlet = (StoreSwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$store");
    ctx.queueManager = (QueueManager) SwiftletManager.getInstance().getSwiftlet("sys$queuemanager");
    ctx.authSwiftlet = (AuthenticationSwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$authentication");
    ctx.threadpoolSwiftlet = (ThreadpoolSwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$threadpool");
    ctx.timerSwiftlet = (TimerSwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$timer");
    if (ctx.traceSpace.enabled)
        ctx.traceSpace.trace(getName(), "startup ...");
    ctx.activeDurableList = (EntityList) root.getEntity("usage").getEntity("durables");
    ctx.activeSubscriberList = (EntityList) root.getEntity("usage").getEntity("subscriber");
    ctx.remoteSubscriberList = (EntityList) root.getEntity("usage").getEntity("subscriber-remote");
    if (ctx.remoteSubscriberList != null) {
        ctx.remoteSubscriberList.setEntityRemoveListener(new EntityRemoveListener() {

            public void onEntityRemove(Entity parent, Entity delEntity) throws EntityRemoveException {
                removeRemoteSubscriptions(delEntity.getName());
                if (ctx.announceSender != null)
                    ctx.announceSender.routerRemoved(delEntity.getName());
            }
        });
        new TopicAnnounceSender(ctx);
    }
    SwiftletManager.getInstance().addSwiftletManagerListener("sys$routing", new SwiftletManagerAdapter() {

        public void swiftletStarted(SwiftletManagerEvent evt) {
            try {
                ctx.routingSwiftlet = (RoutingSwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$routing");
                if (ctx.traceSpace.enabled)
                    ctx.traceSpace.trace(getName(), "starting topic announcer ...");
                Route[] routes = ctx.routingSwiftlet.getRoutes();
                if (routes != null) {
                    for (int i = 0; i < routes.length; i++) {
                        ctx.announceSender.destinationAdded(routes[i]);
                    }
                }
                ctx.routingSwiftlet.addRoutingListener(ctx.announceSender);
            } catch (Exception e) {
                if (ctx.traceSpace.enabled)
                    ctx.traceSpace.trace(getName(), "swiftletStartet, exception=" + e);
            }
            ctx.announceSender.start();
            if (ctx.traceSpace.enabled)
                ctx.traceSpace.trace(getName(), "creating static remote subscriptions ...");
            try {
                createStaticRemoteRouterSubs();
            } catch (SwiftletException e) {
                e.printStackTrace();
                if (ctx.traceSpace.enabled)
                    ctx.traceSpace.trace(getName(), "creating static remote subscriptions ...");
                ctx.logSwiftlet.logError("sys$topicmanager", e.getMessage());
            }
        }
    });
    SwiftletManager.getInstance().addSwiftletManagerListener("sys$jndi", new SwiftletManagerAdapter() {

        public void swiftletStarted(SwiftletManagerEvent evt) {
            try {
                ctx.jndiSwiftlet = (JNDISwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$jndi");
                if (ctx.traceSpace.enabled)
                    ctx.traceSpace.trace(getName(), "registering JNDI topics ...");
                Iterator iter = rootBrokers.entrySet().iterator();
                while (iter.hasNext()) {
                    TopicBroker broker = (TopicBroker) ((Map.Entry) iter.next()).getValue();
                    String[] names = broker.getTopicNames();
                    for (int i = 0; i < names.length; i++) {
                        registerJNDI(names[i], new TopicImpl(names[i]));
                    }
                }
            } catch (Exception e) {
                if (ctx.traceSpace.enabled)
                    ctx.traceSpace.trace(getName(), "swiftletStartet, exception=" + e);
            }
        }
    });
    if (ctx.traceSpace.enabled)
        ctx.traceSpace.trace(getName(), "startup: creating topics ...");
    ctx.logSwiftlet.logInformation(getName(), "startup: creating topics ...");
    try {
        createTopics((EntityList) root.getEntity("topics"));
    } catch (Exception e) {
        throw new SwiftletException(e.getMessage());
    }
    if (ctx.remoteSubscriberList != null) {
        topicQueue = TOPIC_QUEUE + '@' + SwiftletManager.getInstance().getRouterName();
        if (ctx.traceSpace.enabled)
            ctx.traceSpace.trace(getName(), "starting TopicAnnounceReceiver ...");
        try {
            new TopicAnnounceReceiver(ctx, topicQueue);
        } catch (Exception e) {
            throw new SwiftletException(e.getMessage());
        }
    }
    if (ctx.traceSpace.enabled)
        ctx.traceSpace.trace(getName(), "creating durable subscribers ... ");
    try {
        durableSubscriptions = loadDurables();
    } catch (Exception e) {
        throw new SwiftletException("error loading durable subscriptions: " + e);
    }
    Iterator iter = durableSubscriptions.keySet().iterator();
    while (iter.hasNext()) {
        String queueName = (String) iter.next();
        DurableSubscription durable = (DurableSubscription) durableSubscriptions.get(queueName);
        if (ctx.traceSpace.enabled)
            ctx.traceSpace.trace(getName(), "creating durable subscriber: " + durable);
        durableSubscriptions.put(durable.getQueueName(), durable);
        try {
            ctx.queueManager.createQueue(durable.getQueueName(), (ActiveLogin) null);
            TopicImpl topic = new TopicImpl(getQueueForTopic(durable.getTopicName()), durable.getTopicName());
            // it could be the topic isn't defined but it MUST for dursubs!
            try {
                createTopic(topic.getTopicName());
            } catch (Exception ignored) {
            }
            ActiveLogin dlogin = ctx.authSwiftlet.createActiveLogin(durable.getClientId(), DURABLE_TYPE);
            dlogin.setClientId(durable.getClientId());
            int id = subscribe(topic, durable.getSelector(), durable.isNoLocal(), durable.getQueueName(), dlogin);
            durable.setTopicSubscription((TopicSubscription) topicSubscriptions.get(id));
            Entity durEntity = ctx.activeDurableList.createEntity();
            durEntity.setName(durable.getQueueName());
            durEntity.setDynamicObject(durable);
            durEntity.createCommands();
            Property prop = durEntity.getProperty("clientid");
            prop.setValue(dlogin.getClientId());
            prop.setReadOnly(true);
            prop = durEntity.getProperty("durablename");
            prop.setValue(durable.getDurableName());
            prop.setReadOnly(true);
            prop = durEntity.getProperty("topic");
            prop.setValue(durable.getTopicName());
            prop.setReadOnly(true);
            prop = durEntity.getProperty("boundto");
            prop.setValue(durable.getQueueName());
            prop.setReadOnly(true);
            prop = durEntity.getProperty("nolocal");
            prop.setValue(new Boolean(durable.isNoLocal()));
            prop.setReadOnly(true);
            prop = durEntity.getProperty("selector");
            if (durable.getSelector() != null) {
                prop.setValue(durable.getSelector().getConditionString());
            }
            prop.setReadOnly(true);
            ctx.activeDurableList.addEntity(durEntity);
        } catch (Exception e) {
            e.printStackTrace();
            throw new SwiftletException(e.getMessage());
        }
    }
    ctx.activeDurableList.setEntityAddListener(new EntityChangeAdapter(null) {

        public void onEntityAdd(Entity parent, Entity newEntity) throws EntityAddException {
            try {
                if (programmaticDurableInProgress)
                    // do nothing
                    return;
                String clientId = (String) newEntity.getProperty("clientid").getValue();
                SwiftUtilities.verifyClientId(clientId);
                String durableName = (String) newEntity.getProperty("durablename").getValue();
                SwiftUtilities.verifyDurableName(durableName);
                if (!newEntity.getName().equals(clientId + "$" + durableName))
                    throw new Exception("The name of this entity must be: " + clientId + "$" + durableName + " (but it is " + newEntity.getName() + ")");
                if (clientId.indexOf('@') == -1) {
                    clientId = clientId + "@" + SwiftletManager.getInstance().getRouterName();
                    newEntity.getProperty("clientid").setValue(clientId);
                }
                String sel = (String) newEntity.getProperty("selector").getValue();
                MessageSelector selector = null;
                if (sel != null) {
                    selector = new MessageSelector(sel);
                    selector.compile();
                }
                String topicName = (String) newEntity.getProperty("topic").getValue();
                if (!isTopicDefined(topicName))
                    throw new Exception("Unknown topic: " + topicName);
                TopicImpl topic = verifyTopic(new TopicImpl(topicName));
                boolean noLocal = ((Boolean) newEntity.getProperty("nolocal").getValue()).booleanValue();
                ActiveLogin dlogin = ctx.authSwiftlet.createActiveLogin(clientId, DURABLE_TYPE);
                dlogin.setClientId(clientId);
                subscribeDurable(durableName, topic, selector, noLocal, dlogin, newEntity, false);
                if (ctx.traceSpace.enabled)
                    ctx.traceSpace.trace(getName(), "onEntityAdd (durable): new durable=" + newEntity.getName());
            } catch (Exception e) {
                throw new EntityAddException(e.getMessage());
            }
        }
    });
    ctx.activeDurableList.setEntityRemoveListener(new EntityChangeAdapter(null) {

        public void onEntityRemove(Entity parent, Entity delEntity) throws EntityRemoveException {
            try {
                DurableSubscription myDurable = (DurableSubscription) delEntity.getDynamicObject();
                ActiveLogin myLogin = ctx.authSwiftlet.createActiveLogin(myDurable.getClientId(), "DURABLE");
                myLogin.setClientId(myDurable.getClientId());
                deleteDurable(myDurable.getDurableName(), myLogin);
                if (ctx.traceSpace.enabled)
                    ctx.traceSpace.trace(getName(), "onEntityRemove (durable): del durable=" + myDurable);
            } catch (Exception e) {
                throw new EntityRemoveException(e.getMessage());
            }
        }
    });
    createSlowSubscriberConditions();
    SwiftletManager.getInstance().addSwiftletManagerListener("sys$scheduler", new SwiftletManagerAdapter() {

        public void swiftletStarted(SwiftletManagerEvent event) {
            jobRegistrar = new JobRegistrar(TopicManagerImpl.this, (SchedulerSwiftlet) SwiftletManager.getInstance().getSwiftlet("sys$scheduler"), ctx);
            jobRegistrar.register();
        }

        public void swiftletStopInitiated(SwiftletManagerEvent event) {
            jobRegistrar.unregister();
        }
    });
    if (ctx.traceSpace.enabled)
        ctx.traceSpace.trace(getName(), "startup done.");
}
Also used : JNDISwiftlet(com.swiftmq.swiftlet.jndi.JNDISwiftlet) SwiftletManagerAdapter(com.swiftmq.swiftlet.event.SwiftletManagerAdapter) RoutingSwiftlet(com.swiftmq.swiftlet.routing.RoutingSwiftlet) DurableStoreEntry(com.swiftmq.swiftlet.store.DurableStoreEntry) ActiveLogin(com.swiftmq.swiftlet.auth.ActiveLogin) SwiftletManagerEvent(com.swiftmq.swiftlet.event.SwiftletManagerEvent) MessageSelector(com.swiftmq.ms.MessageSelector) TopicImpl(com.swiftmq.jms.TopicImpl) TopicAnnounceSender(com.swiftmq.impl.topic.standard.announce.TopicAnnounceSender) JobRegistrar(com.swiftmq.impl.topic.standard.jobs.JobRegistrar) InvalidDestinationException(javax.jms.InvalidDestinationException) IOException(java.io.IOException) JMSException(javax.jms.JMSException) SwiftletException(com.swiftmq.swiftlet.SwiftletException) AuthenticationException(com.swiftmq.swiftlet.auth.AuthenticationException) TopicException(com.swiftmq.swiftlet.topic.TopicException) SwiftletException(com.swiftmq.swiftlet.SwiftletException) TopicAnnounceReceiver(com.swiftmq.impl.topic.standard.announce.TopicAnnounceReceiver)

Example 30 with MessageSelector

use of com.swiftmq.ms.MessageSelector in project swiftmq-ce by iitsoftware.

the class DurableSubscription method getSelector.

public Selector getSelector() {
    if (condition != null && selector == null) {
        try {
            MessageSelector ms = new MessageSelector(condition);
            ms.compile();
            selector = ms;
        } catch (Exception ignored) {
        }
    }
    return selector;
}
Also used : MessageSelector(com.swiftmq.ms.MessageSelector)

Aggregations

MessageSelector (com.swiftmq.ms.MessageSelector)31 InvalidSelectorException (javax.jms.InvalidSelectorException)11 QueueImpl (com.swiftmq.jms.QueueImpl)9 InvalidDestinationException (javax.jms.InvalidDestinationException)8 JMSException (javax.jms.JMSException)8 Entity (com.swiftmq.mgmt.Entity)7 Property (com.swiftmq.mgmt.Property)7 MessageImpl (com.swiftmq.jms.MessageImpl)5 TopicImpl (com.swiftmq.jms.TopicImpl)4 IllegalStateException (javax.jms.IllegalStateException)4 QueueReceiver (com.swiftmq.swiftlet.queue.QueueReceiver)3 JobException (com.swiftmq.swiftlet.scheduler.JobException)3 Iterator (java.util.Iterator)3 Map (java.util.Map)3 Message (com.swiftmq.impl.streams.comp.message.Message)2 QueueMessageProcessor (com.swiftmq.impl.streams.processor.QueueMessageProcessor)2 EntityRemoveException (com.swiftmq.mgmt.EntityRemoveException)2 ActiveLogin (com.swiftmq.swiftlet.auth.ActiveLogin)2 AuthenticationException (com.swiftmq.swiftlet.auth.AuthenticationException)2 AbstractQueue (com.swiftmq.swiftlet.queue.AbstractQueue)2