Search in sources :

Example 6 with ConsumerSpi

use of com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi in project openmq by eclipse-ee4j.

the class Session method fillNextPacket.

public ConsumerUID fillNextPacket(Packet p) {
    if (paused) {
        return null;
    }
    ConsumerUID cid = null;
    ConsumerSpi consumer = null;
    while (!paused) {
        // get a consumer
        synchronized (busyConsumers) {
            if (busyConsumers.isEmpty()) {
                break;
            }
            Iterator itr = busyConsumers.iterator();
            cid = (ConsumerUID) itr.next();
            consumer = (ConsumerSpi) consumers.get(cid);
            itr.remove();
        }
        assert p != null;
        if (consumer == null) {
            return null;
        }
        Object ref = null;
        synchronized (sessionLock) {
            if (paused) {
                synchronized (busyConsumers) {
                    if (consumer.isBusy()) {
                        busyConsumers.add(cid);
                    }
                }
                return null;
            }
            ref = consumer.getAndFillNextPacket(p);
            synchronized (busyConsumers) {
                if (consumer.isBusy()) {
                    busyConsumers.add(cid);
                }
            }
            if (ref == null) {
                continue;
            }
            if (!ssop.onMessageDelivery(consumer, ref)) {
                continue;
            }
        }
        checkState(null);
        return (cid != null ? cid : null);
    }
    checkState(null);
    return null;
}
Also used : Iterator(java.util.Iterator) ConsumerSpi(com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi)

Example 7 with ConsumerSpi

use of com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi in project openmq by eclipse-ee4j.

the class Session method detatchConsumer.

/**
 * clean indicated that it was made by a 3.5 consumer calling close
 *
 * @param id last SysMessageID seen (null indicates all have been seen)
 * @param redeliverAll ignore id and redeliver all
 * @param redeliverPendingConsume - redeliver pending messages
 */
public ConsumerSpi detatchConsumer(ConsumerUID c, SysMessageID id, boolean idInTransaction, boolean redeliverPendingConsume, boolean redeliverAll) throws BrokerException {
    pause("Consumer.java: detatch consumer " + c);
    ConsumerSpi con = (ConsumerSpi) consumers.remove(c);
    if (con == null) {
        resume("Consumer.java: bad removal " + c);
        throw new BrokerException("Detatching consumer " + c + " not currently attached " + "to " + this);
    }
    // we dont want to ever remove messages
    con.pause("Consumer.java: detatch consumer " + c + " DEAD");
    detatchConsumer(con, id, idInTransaction, redeliverPendingConsume, redeliverAll);
    resume("Consumer.java: detatch consumer " + c);
    return con;
}
Also used : BrokerException(com.sun.messaging.jmq.jmsserver.util.BrokerException) ConsumerSpi(com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi)

Example 8 with ConsumerSpi

use of com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi in project openmq by eclipse-ee4j.

the class FlowHandler method handle.

/**
 * Method to handle flow messages
 */
@Override
public boolean handle(IMQConnection con, Packet msg) throws BrokerException {
    if (DEBUG) {
        logger.log(Logger.DEBUGHIGH, "FlowHandler: handle() [ Received Flow  Message]");
    }
    assert msg.getPacketType() == PacketType.RESUME_FLOW;
    Hashtable props = null;
    try {
        props = msg.getProperties();
    } catch (Exception ex) {
        logger.logStack(Logger.WARNING, "RESUME-FLOW Packet.getProperties()", ex);
        props = new Hashtable();
    }
    Integer bufsize = null;
    ConsumerSpi consumer = null;
    if (props != null) {
        bufsize = (Integer) props.get("JMQSize");
        if (bufsize == null) {
            // try old protocol
            bufsize = (Integer) props.get("JMQRBufferSize");
        }
        Long cuid = (Long) props.get("JMQConsumerID");
        if (cuid != null) {
            ConsumerUID tmpuid = new ConsumerUID(cuid.longValue());
            consumer = coreLifecycle.getConsumer(tmpuid);
        }
    }
    if (DEBUG) {
        logger.log(Logger.DEBUG, "Setting JMQRBufferSize -" + bufsize);
    }
    if (consumer != null) {
        // consumer flow control
        int size = (bufsize == null ? -1 : bufsize.intValue());
        consumerFlow(consumer, size);
    } else {
        // connection flow control
        int size = (bufsize == null ? -1 : bufsize.intValue());
        connectionFlow(con, size);
    }
    return true;
}
Also used : ConsumerUID(com.sun.messaging.jmq.jmsserver.core.ConsumerUID) ConsumerSpi(com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi) BrokerException(com.sun.messaging.jmq.jmsserver.util.BrokerException)

Example 9 with ConsumerSpi

use of com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi in project openmq by eclipse-ee4j.

the class IMQConnection method getConsumers.

public List getConsumers() {
    ArrayList cons = new ArrayList();
    Iterator itr = sessions.values().iterator();
    while (itr.hasNext()) {
        Session s = (Session) itr.next();
        Iterator citr = s.getConsumers();
        while (citr.hasNext()) {
            ConsumerSpi c = (ConsumerSpi) citr.next();
            cons.add(c);
        }
    }
    return cons;
}
Also used : ConsumerSpi(com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi) Session(com.sun.messaging.jmq.jmsserver.core.Session)

Example 10 with ConsumerSpi

use of com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi in project openmq by eclipse-ee4j.

the class DebugHandler method handle.

/**
 * Handle the incomming administration message.
 *
 * @param con The Connection the message came in on.
 * @param cmd_msg The administration message
 * @param cmd_props The properties from the administration message
 */
@Override
public boolean handle(IMQConnection con, Packet cmd_msg, Hashtable cmd_props) {
    int status = Status.OK;
    String msg = null;
    boolean logOnly = false;
    if (DEBUG) {
        logger.log(Logger.DEBUG, this.getClass().getName() + ": " + cmd_props);
    }
    String cmd = (String) cmd_props.get(MessageType.JMQ_CMD), cmdarg = (String) cmd_props.get(MessageType.JMQ_CMDARG), target = (String) cmd_props.get(MessageType.JMQ_TARGET), targetType = (String) cmd_props.get(MessageType.JMQ_TARGET_TYPE);
    // Get properties we are to update from message body
    Properties p = (Properties) getBodyObject(cmd_msg);
    /*
         * To always see output (when debugging/developing this handler) change: if (DEBUG) to if (true)
         *
         * and Logger.DEBUG to Logger.INFO
         */
    if (DEBUG) {
        logger.log(Logger.DEBUG, "DEBUG message received:");
        logger.log(Logger.DEBUG, "\t" + MessageType.JMQ_CMD + ": " + cmd);
        logger.log(Logger.DEBUG, "\t" + MessageType.JMQ_CMDARG + ": " + cmdarg);
        logger.log(Logger.DEBUG, "\t" + MessageType.JMQ_TARGET + ": " + target);
        logger.log(Logger.DEBUG, "\tOptional Properties: " + p);
    }
    /*
         * CHECK: Should make sure relevant values above are non null (e.g. cmd).
         */
    Hashtable debugHash = null;
    String fileStr = p.getProperty("file");
    // Send reply
    Packet reply = new Packet(con.useDirectBuffers());
    reply.setPacketType(PacketType.OBJECT_MESSAGE);
    if ((cmd == null) || (cmdarg == null)) {
        status = Status.BAD_REQUEST;
        msg = "Null/Missing values for " + MessageType.JMQ_CMD + " and/or " + MessageType.JMQ_CMDARG + " properties.";
        setProperties(reply, MessageType.DEBUG_REPLY, status, msg);
        parent.sendReply(con, cmd_msg, reply);
        return true;
    }
    if (cmd.equals("update") && cmdarg.equals("bkr")) {
        // Get properties we are to update from message body
        // Update the broker configuration
        BrokerConfig bcfg = Globals.getConfig();
        try {
            bcfg.updateProperties(p, true);
        } catch (PropertyUpdateException e) {
            status = Status.BAD_REQUEST;
            msg = e.getMessage();
            logger.log(Logger.WARNING, msg);
        } catch (IOException e) {
            status = Status.ERROR;
            msg = e.toString();
            logger.log(Logger.WARNING, msg);
        }
        // Send reply
        setProperties(reply, MessageType.DEBUG_REPLY, status, msg);
        parent.sendReply(con, cmd_msg, reply);
        return true;
    } else if (cmd.equals("dump") || cmd.equals("query")) {
        if (cmd.equals("dump")) {
            logOnly = true;
            if (fileStr == null) {
                fileStr = "dumpOutput";
            }
        }
        try {
            debugHash = getDebugInfo(cmdarg, target, targetType, p);
        } catch (Exception ex) {
            status = Status.ERROR;
            msg = "Error " + cmd + "ing " + cmdarg + " because " + ex.getMessage();
            logger.logStack(Logger.INFO, msg, ex);
        }
    } else if (cmd.equals("list")) {
        debugHash = new Hashtable();
        if (cmdarg.equals("dst")) {
            Iterator[] itrs = DL.getAllDestinations(null);
            Iterator itr = itrs[0];
            while (itr.hasNext()) {
                Destination d = (Destination) itr.next();
                debugHash.put(d.getDestinationUID().toString(), DestType.toString(d.getType()) + ":" + (d.isStored() ? "stored" : "not stored"));
            }
        } else if (cmdarg.equals("con")) {
            debugHash = new Hashtable();
            if (target == null) {
                // all
                Iterator itr = Consumer.getAllConsumers();
                if (!itr.hasNext()) {
                    status = Status.ERROR;
                    msg = "No consumers on the broker";
                }
                while (itr.hasNext()) {
                    Consumer c = (Consumer) itr.next();
                    if (c == null) {
                        continue;
                    }
                    IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(c.getConnectionUID());
                    ConsumerUID cuid = c.getConsumerUID();
                    ConnectionUID cxuid = c.getConnectionUID();
                    debugHash.put(String.valueOf((cuid == null ? 0 : cuid.longValue())), (cxn == null ? "none" : cxn.getRemoteConnectionString()) + " [" + (cxuid == null ? 0 : cxuid.longValue()) + "]");
                }
            } else if (targetType == null) {
                msg = "Please supply targetType if you are supplying a target ";
                status = Status.ERROR;
            } else if (targetType.equals("t") || targetType.equals("q")) {
                try {
                    boolean isQueue = false;
                    if (targetType.equals("q")) {
                        isQueue = true;
                    }
                    DestinationUID uid = null;
                    Destination d = null;
                    if (status != Status.ERROR) {
                        uid = DestinationUID.getUID(target, isQueue);
                        Destination[] ds = DL.getDestination(null, uid);
                        d = ds[0];
                    }
                    if (status != Status.ERROR && d == null) {
                        status = Status.ERROR;
                        msg = "Error listing consumers on destination  " + target + " unknown destination";
                    } else if (status != Status.ERROR) {
                        Iterator itr = d.getConsumers();
                        if (!itr.hasNext()) {
                            status = Status.ERROR;
                            msg = "No consumers on destination  " + target;
                        }
                        while (itr.hasNext()) {
                            Consumer c = (Consumer) itr.next();
                            IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(c.getConnectionUID());
                            debugHash.put(String.valueOf(c.getConsumerUID().longValue()), (cxn == null ? "" : cxn.getRemoteConnectionString()) + " [" + (c.getConnectionUID() == null ? "none" : c.getConnectionUID().longValue()) + "]");
                        }
                    }
                } catch (Exception ex) {
                    status = Status.ERROR;
                    msg = "Error listing consumers on connection  " + target + " because " + ex.toString();
                    logger.logStack(Logger.INFO, msg, ex);
                }
            } else if (targetType.equals("ses")) {
                try {
                    SessionUID uid = new SessionUID(Long.parseLong(target));
                    Session ses = Session.getSession(uid);
                    if (ses == null) {
                        status = Status.ERROR;
                        msg = "Error listing consumers on session  " + target + " unknown sessionUID";
                    } else {
                        Iterator itr = ses.getConsumers();
                        if (!itr.hasNext()) {
                            status = Status.ERROR;
                            msg = "No consumers on session  " + target;
                        }
                        while (itr.hasNext()) {
                            ConsumerSpi c = (ConsumerSpi) itr.next();
                            if (uid.equals(c.getConnectionUID())) {
                                debugHash.put(String.valueOf(c.getConsumerUID().longValue()), c.getDestinationUID().toString());
                            }
                        }
                    }
                } catch (Exception ex) {
                    status = Status.ERROR;
                    msg = "Error listing consumers on connection  " + target + " because " + ex.toString();
                    logger.logStack(Logger.INFO, msg, ex);
                }
            } else if (targetType.equals("cxn")) {
                try {
                    ConnectionUID uid = new ConnectionUID(Long.parseLong(target));
                    IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(uid);
                    if (cxn == null) {
                        status = Status.ERROR;
                        msg = "Error listing consumers on connection  " + target + " unknown connectionUID";
                    } else {
                        Iterator itr = Consumer.getAllConsumers();
                        while (itr.hasNext()) {
                            Consumer c = (Consumer) itr.next();
                            if (uid.equals(c.getConnectionUID())) {
                                debugHash.put(String.valueOf(c.getConsumerUID().longValue()), c.getDestinationUID().toString());
                            }
                        }
                    }
                } catch (Exception ex) {
                    status = Status.ERROR;
                    msg = "Error listing consumers on connection  " + target + " because " + ex.toString();
                    logger.logStack(Logger.INFO, msg, ex);
                }
            } else {
                status = Status.ERROR;
                msg = "Unknown targetType (-t) " + target + "\n Valid formats are of the form: " + "[q|t|ses|cxn]";
            }
        } else if (cmdarg.equals("prd")) {
            debugHash = new Hashtable();
            if (target == null) {
                // all
                Iterator itr = Producer.getAllProducers();
                while (itr.hasNext()) {
                    Producer c = (Producer) itr.next();
                    IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(c.getConnectionUID());
                    debugHash.put(String.valueOf(c.getProducerUID().longValue()), cxn.getRemoteConnectionString() + " [" + c.getConnectionUID().longValue() + "]");
                }
            } else if (targetType == null) {
                msg = "Please supply targetType if you are supplying a target ";
                status = Status.ERROR;
            } else if (targetType.equals("t") || targetType.equals("q")) {
                // destination
                boolean isQueue = false;
                if (targetType.equals("q")) {
                    isQueue = true;
                }
                try {
                    DestinationUID uid = DestinationUID.getUID(target, isQueue);
                    Destination[] ds = DL.getDestination(null, uid);
                    Destination d = ds[0];
                    if (d == null) {
                        status = Status.ERROR;
                        msg = "Error listing producers on destination  " + target + " unknown destination";
                    } else {
                        Iterator itr = d.getProducers();
                        while (itr.hasNext()) {
                            Producer c = (Producer) itr.next();
                            IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(c.getConnectionUID());
                            debugHash.put(String.valueOf(c.getProducerUID().longValue()), cxn.getRemoteConnectionString() + " [" + c.getConnectionUID().longValue() + "]");
                        }
                    }
                } catch (Exception ex) {
                    status = Status.ERROR;
                    msg = "Error listing producers on connection  " + target + " because " + ex.toString();
                    logger.logStack(Logger.INFO, msg, ex);
                }
            } else if (targetType.equals("cxn")) {
                try {
                    ConnectionUID uid = new ConnectionUID(Long.parseLong(target));
                    IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(uid);
                    if (cxn == null) {
                        status = Status.ERROR;
                        msg = "Error listing producers on connection  " + target + " unknown connectionUID";
                    } else {
                        Iterator itr = Producer.getAllProducers();
                        while (itr.hasNext()) {
                            Producer c = (Producer) itr.next();
                            if (uid.equals(c.getConnectionUID())) {
                                debugHash.put(String.valueOf(c.getProducerUID().longValue()), c.getDestinationUID().toString());
                            }
                        }
                    }
                } catch (Exception ex) {
                    status = Status.ERROR;
                    msg = "Error listing producers on connection  " + target + " because " + ex.toString();
                    logger.logStack(Logger.INFO, msg, ex);
                }
            } else {
                status = Status.ERROR;
                msg = "Unknown targetType (-t) " + targetType + "\n Valid formats are of the form: " + "[t|q|cxn]";
            }
        } else {
            status = Status.ERROR;
            msg = "Unknown argument " + cmdarg;
        }
    } else if (cmd.equals("debug")) {
        String debugStr = (String) p.get("enable");
        if (debugStr != null && !debugStr.equalsIgnoreCase("true") && !debugStr.equalsIgnoreCase("false")) {
            status = Status.ERROR;
            msg = "bad enable flag setting " + debugStr + " defauling to false";
        }
        boolean debugOn = debugStr == null || Boolean.parseBoolean(debugStr);
        if (cmdarg.equals("reset")) {
            if (targetType == null) {
                msg = "Please supply targetType (-t)\n Valid formats are of the form: [metrics|jdbcconnpool]";
                status = Status.ERROR;
            } else if (targetType.equalsIgnoreCase("jdbcconnpool")) {
                try {
                    if (Globals.getStore().isJDBCStore()) {
                        Globals.getStore().resetConnectionPool();
                    } else {
                        status = Status.ERROR;
                        msg = "Operation is not applicable for a file-based data store.";
                    }
                } catch (Exception ex) {
                    status = Status.ERROR;
                    msg = "Error resetting JDBC connection pool because " + ex.toString();
                    logger.logStack(Logger.INFO, msg, ex);
                }
            } else if (targetType.equalsIgnoreCase("metrics")) {
                com.sun.messaging.jmq.jmsserver.data.handlers.admin.ResetMetricsHandler.resetAllMetrics();
            }
        } else if (cmdarg.equals("fault")) {
            // handle fault injection
            String faultName = (String) p.get("name");
            if (faultName == null) {
                faultName = target;
            }
            String faultSelector = (String) p.get("selector");
            FaultInjection fi = FaultInjection.getInjection();
            // ok only turn off fault injection if no name pair
            if (debugStr != null && debugStr.equalsIgnoreCase("false")) {
                if (faultName == null) {
                    fi.setFaultInjection(false);
                } else {
                    fi.unsetFault(faultName);
                }
            } else {
                fi.setFaultInjection(true);
                if (faultName != null) {
                    try {
                        fi.setFault(faultName, faultSelector, p);
                    } catch (Exception ex) {
                        status = Status.ERROR;
                        msg = "Bad Selector " + faultSelector;
                    }
                }
            }
        } else if (cmdarg.equals("gc")) {
            logger.log(Logger.INFO, "GC'ing the system");
            System.gc();
            long usedMem = (Runtime.getRuntime().totalMemory() - Runtime.getRuntime().freeMemory());
            msg = "Used memory is " + (usedMem / 1024l) + "k, " + " this is " + (usedMem * 100 / Runtime.getRuntime().maxMemory()) + "% of " + (Runtime.getRuntime().maxMemory() / 1024l) + "k";
            logger.log(Logger.INFO, msg);
            debugHash = new Hashtable();
            debugHash.put("Memory", msg);
            debugHash.put("Used", (usedMem / 1024l) + "k");
            debugHash.put("Total", ((Runtime.getRuntime().totalMemory() / 1024l) + "k"));
            debugHash.put("Free", ((Runtime.getRuntime().freeMemory() / 1024l) + "k"));
            debugHash.put("Max", ((Runtime.getRuntime().maxMemory() / 1024l) + "k"));
        } else if (cmdarg.equals("threads")) {
            // log
            try {
                debugHash = new Hashtable();
                debugHash.put("threads", "dumped to log");
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Error " + cmd + "ing " + cmdarg + " because " + ex.getMessage() + "";
                logger.logStack(Logger.INFO, msg, ex);
            }
            logger.log(Logger.INFO, "Dumping threads:\n" + SupportUtil.getAllStackTraces("\t"));
        } else if (cmdarg.equals("pkt")) {
            IMQBasicConnection.dumpPacket(debugOn);
        } else if (cmdarg.equals("pktin")) {
            IMQBasicConnection.dumpInPacket(debugOn);
        } else if (cmdarg.equals("pktout")) {
            IMQBasicConnection.dumpOutPacket(debugOn);
        } else if (cmdarg.equals("class")) {
            try {
                Class cl = Class.forName(target);
                Field[] fields = cl.getDeclaredFields();
                boolean found = false;
                for (int i = 0; i < fields.length; i++) {
                    if (fields[i].getName().equals(Debug.debugFieldName)) {
                        logger.log(Logger.INFO, "Turn " + (debugOn ? "on" : "off") + " debug for class " + target);
                        final Field f = fields[i];
                        java.security.AccessController.doPrivileged(new java.security.PrivilegedAction<Object>() {

                            @Override
                            public Object run() {
                                f.setAccessible(true);
                                return null;
                            }
                        });
                        fields[i].setBoolean(null, debugOn);
                        found = true;
                        break;
                    }
                }
                if (!found) {
                    throw new NoSuchFieldException(Debug.debugFieldName);
                }
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Unable to set DEBUG on class " + target + " because " + ex.toString();
                logger.logStack(Logger.INFO, msg, ex);
            }
        } else {
            status = Status.ERROR;
            msg = "Unknown debug argument " + cmdarg;
        }
    } else if (cmd.equals("resume")) {
        // session, connection, consumerUID, producer
        if (cmdarg.equals("prd")) {
            try {
                ProducerUID pid = new ProducerUID(Long.parseLong(target));
                Producer pr = (Producer) Producer.getProducer(pid);
                Destination[] ds = DL.getDestination(null, pr.getDestinationUID());
                Destination d = ds[0];
                logger.log(Logger.INFO, "Resuming " + pr);
                d.forceResumeFlow(pr);
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Error resuming flow from producer  " + target + " because " + ex.toString();
                logger.logStack(Logger.INFO, msg, ex);
            }
        } else if (cmdarg.equals("cxn")) {
            try {
                ConnectionUID uid = new ConnectionUID(Long.parseLong(target));
                IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(uid);
                cxn.resumeFlow(-1);
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Error resuming flow on connection  " + target + " because " + ex.toString();
                logger.logStack(Logger.INFO, msg, ex);
            }
        } else if (cmdarg.equals("con")) {
            try {
                ConsumerUID cid = new ConsumerUID(Long.parseLong(target));
                Consumer cxn = Consumer.getConsumer(cid);
                cxn.resume("admin debug");
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Error resuming flow to consumer  " + target + " because " + ex.toString();
                logger.logStack(Logger.INFO, msg, ex);
            }
        } else if (cmdarg.equals("ses")) {
            try {
                SessionUID sid = new SessionUID(Long.parseLong(target));
                Session session = Session.getSession(sid);
                session.resume("admin debug");
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Error resuming flow to session  " + target + " because " + ex.toString();
                logger.logStack(Logger.INFO, msg, ex);
            }
        } else {
            status = Status.ERROR;
            msg = "Unknown resume argument " + cmdarg;
        }
    } else if (cmd.equals("send")) {
        if (cmdarg.equals("cxn")) {
            try {
                if (target == null) {
                    status = Status.ERROR;
                    msg = "Missing connectionUID ";
                } else {
                    ConnectionUID uid = new ConnectionUID(Long.parseLong(target));
                    IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(uid);
                    if (cxn == null) {
                        status = Status.ERROR;
                        msg = "Unknown connectionUID " + uid;
                    } else {
                        sendClientDEBUG(cxn, cmd_props, p);
                    }
                }
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Error notifying consumer  " + target + " because " + ex.toString();
                logger.logStack(Logger.INFO, msg, ex);
            }
        } else if (cmdarg.equals("bkr") || cmdarg.equals("svc")) {
            Service s = null;
            if (target != null) {
                s = Globals.getServiceManager().getService(target);
                if (s == null) {
                    msg = "Unknown service " + target;
                    status = Status.ERROR;
                }
            }
            Iterator itr = Globals.getConnectionManager().getConnectionList(s).iterator();
            try {
                while (itr.hasNext()) {
                    IMQConnection cxn = (IMQConnection) itr.next();
                    Packet pkt = new Packet(false);
                    pkt.setPacketType(PacketType.DEBUG);
                    Hashtable hash = new Hashtable(cmd_props);
                    ByteArrayOutputStream bos = new ByteArrayOutputStream();
                    ObjectOutputStream oos = new ObjectOutputStream(bos);
                    oos.writeObject(p);
                    oos.flush();
                    bos.flush();
                    pkt.setMessageBody(bos.toByteArray());
                    pkt.setProperties(hash);
                    cxn.sendControlMessage(pkt);
                }
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Error notifying consumer  " + target + " because " + ex.toString();
                logger.logStack(Logger.INFO, msg, ex);
            }
        } else {
            status = Status.ERROR;
            msg = "Unknown send argument " + cmdarg;
        }
    } else if (cmd.equals("kill")) {
        if (cmdarg.equals("cxn")) {
            try {
                ConnectionUID uid = new ConnectionUID(Long.parseLong(target));
                IMQConnection cxn = (IMQConnection) Globals.getConnectionManager().getConnection(uid);
                cxn.destroyConnection(true, GoodbyeReason.ADMIN_KILLED_CON, "kill cnx");
            } catch (Exception ex) {
                status = Status.ERROR;
                msg = "Error killing connection  " + target + " because " + ex.toString();
                logger.logStack(Logger.INFO, msg, ex);
            }
        } else {
            status = Status.ERROR;
            msg = "Unknown kill argument " + cmdarg;
        }
    }
    if (fileStr != null && debugHash != null) {
        DebugPrinter dbp = new DebugPrinter(2);
        dbp.setHashtable(debugHash);
        dbp.setFile(fileStr);
        dbp.println();
        dbp.close();
        if (status == Status.OK) {
            msg = "Data logged at file " + fileStr;
        }
        if (logOnly) {
            debugHash = new Hashtable();
            debugHash.put("logfile", fileStr);
        }
    }
    if (msg != null) {
        logger.log(Logger.INFO, msg);
    }
    setProperties(reply, MessageType.DEBUG_REPLY, status, msg);
    if (debugHash != null) {
        setBodyObject(reply, debugHash);
    }
    parent.sendReply(con, cmd_msg, reply);
    return true;
}
Also used : Destination(com.sun.messaging.jmq.jmsserver.core.Destination) ProducerUID(com.sun.messaging.jmq.jmsserver.core.ProducerUID) ConsumerSpi(com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi) Properties(java.util.Properties) Consumer(com.sun.messaging.jmq.jmsserver.core.Consumer) IMQConnection(com.sun.messaging.jmq.jmsserver.service.imq.IMQConnection) Iterator(java.util.Iterator) ConsumerUID(com.sun.messaging.jmq.jmsserver.core.ConsumerUID) SessionUID(com.sun.messaging.jmq.jmsserver.core.SessionUID) Hashtable(java.util.Hashtable) Service(com.sun.messaging.jmq.jmsserver.service.Service) FaultInjection(com.sun.messaging.jmq.jmsserver.FaultInjection) DestinationUID(com.sun.messaging.jmq.jmsserver.core.DestinationUID) Producer(com.sun.messaging.jmq.jmsserver.core.Producer) ConnectionUID(com.sun.messaging.jmq.jmsserver.service.ConnectionUID) DebugPrinter(com.sun.messaging.jmq.util.DebugPrinter) Session(com.sun.messaging.jmq.jmsserver.core.Session)

Aggregations

ConsumerSpi (com.sun.messaging.jmq.jmsserver.plugin.spi.ConsumerSpi)10 Iterator (java.util.Iterator)5 Session (com.sun.messaging.jmq.jmsserver.core.Session)3 ConsumerUID (com.sun.messaging.jmq.jmsserver.core.ConsumerUID)2 BrokerException (com.sun.messaging.jmq.jmsserver.util.BrokerException)2 FaultInjection (com.sun.messaging.jmq.jmsserver.FaultInjection)1 Consumer (com.sun.messaging.jmq.jmsserver.core.Consumer)1 Destination (com.sun.messaging.jmq.jmsserver.core.Destination)1 DestinationUID (com.sun.messaging.jmq.jmsserver.core.DestinationUID)1 Producer (com.sun.messaging.jmq.jmsserver.core.Producer)1 ProducerUID (com.sun.messaging.jmq.jmsserver.core.ProducerUID)1 SessionUID (com.sun.messaging.jmq.jmsserver.core.SessionUID)1 Connection (com.sun.messaging.jmq.jmsserver.service.Connection)1 ConnectionUID (com.sun.messaging.jmq.jmsserver.service.ConnectionUID)1 Service (com.sun.messaging.jmq.jmsserver.service.Service)1 IMQConnection (com.sun.messaging.jmq.jmsserver.service.imq.IMQConnection)1 DebugPrinter (com.sun.messaging.jmq.util.DebugPrinter)1 HashSet (java.util.HashSet)1 Hashtable (java.util.Hashtable)1 LinkedHashSet (java.util.LinkedHashSet)1