Datasets:

Modalities:
Text
Formats:
json
Languages:
code
Size:
< 1K
Tags:
code
Libraries:
Datasets
pandas
License:
File size: 61,327 Bytes
4fb7874
1
/** * * Copyright 2009 Jive Software. * * Licensed under the Apache License, Version 2.0 (the "License"); * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * *     http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */package org.jivesoftware.smack;import java.io.IOException;import java.io.Reader;import java.io.Writer;import java.util.ArrayList;import java.util.Collection;import java.util.HashMap;import java.util.LinkedHashMap;import java.util.LinkedList;import java.util.List;import java.util.Map;import java.util.Set;import java.util.concurrent.ConcurrentLinkedQueue;import java.util.concurrent.CopyOnWriteArraySet;import java.util.concurrent.ExecutorService;import java.util.concurrent.Executors;import java.util.concurrent.ScheduledExecutorService;import java.util.concurrent.ScheduledFuture;import java.util.concurrent.TimeUnit;import java.util.concurrent.atomic.AtomicInteger;import java.util.concurrent.locks.Lock;import java.util.concurrent.locks.ReentrantLock;import java.util.logging.Level;import java.util.logging.Logger;import org.jivesoftware.smack.ConnectionConfiguration.SecurityMode;import org.jivesoftware.smack.SmackException.AlreadyConnectedException;import org.jivesoftware.smack.SmackException.AlreadyLoggedInException;import org.jivesoftware.smack.SmackException.NoResponseException;import org.jivesoftware.smack.SmackException.NotConnectedException;import org.jivesoftware.smack.SmackException.ConnectionException;import org.jivesoftware.smack.SmackException.ResourceBindingNotOfferedException;import org.jivesoftware.smack.SmackException.SecurityRequiredException;import org.jivesoftware.smack.XMPPException.XMPPErrorException;import org.jivesoftware.smack.compress.packet.Compress;import org.jivesoftware.smack.compression.XMPPInputOutputStream;import org.jivesoftware.smack.debugger.SmackDebugger;import org.jivesoftware.smack.filter.IQReplyFilter;import org.jivesoftware.smack.filter.StanzaFilter;import org.jivesoftware.smack.filter.StanzaIdFilter;import org.jivesoftware.smack.iqrequest.IQRequestHandler;import org.jivesoftware.smack.packet.Bind;import org.jivesoftware.smack.packet.ErrorIQ;import org.jivesoftware.smack.packet.IQ;import org.jivesoftware.smack.packet.Mechanisms;import org.jivesoftware.smack.packet.Stanza;import org.jivesoftware.smack.packet.ExtensionElement;import org.jivesoftware.smack.packet.Presence;import org.jivesoftware.smack.packet.Session;import org.jivesoftware.smack.packet.StartTls;import org.jivesoftware.smack.packet.PlainStreamElement;import org.jivesoftware.smack.packet.XMPPError;import org.jivesoftware.smack.parsing.ParsingExceptionCallback;import org.jivesoftware.smack.parsing.UnparsablePacket;import org.jivesoftware.smack.provider.ExtensionElementProvider;import org.jivesoftware.smack.provider.ProviderManager;import org.jivesoftware.smack.util.BoundedThreadPoolExecutor;import org.jivesoftware.smack.util.DNSUtil;import org.jivesoftware.smack.util.Objects;import org.jivesoftware.smack.util.PacketParserUtils;import org.jivesoftware.smack.util.ParserUtils;import org.jivesoftware.smack.util.SmackExecutorThreadFactory;import org.jivesoftware.smack.util.StringUtils;import org.jivesoftware.smack.util.dns.HostAddress;import org.jxmpp.util.XmppStringUtils;import org.xmlpull.v1.XmlPullParser;import org.xmlpull.v1.XmlPullParserException;public abstract class AbstractXMPPConnection implements XMPPConnection {    private static final Logger LOGGER = Logger.getLogger(AbstractXMPPConnection.class.getName());    /**      * Counter to uniquely identify connections that are created.     */    private final static AtomicInteger connectionCounter = new AtomicInteger(0);    static {        // Ensure the SmackConfiguration class is loaded by calling a method in it.        SmackConfiguration.getVersion();    }    /**     * Get the collection of listeners that are interested in connection creation events.     *      * @return a collection of listeners interested on new connections.     */    protected static Collection<ConnectionCreationListener> getConnectionCreationListeners() {        return XMPPConnectionRegistry.getConnectionCreationListeners();    }     /**     * A collection of ConnectionListeners which listen for connection closing     * and reconnection events.     */    protected final Set<ConnectionListener> connectionListeners =            new CopyOnWriteArraySet<ConnectionListener>();    /**     * A collection of PacketCollectors which collects packets for a specified filter     * and perform blocking and polling operations on the result queue.     * <p>     * We use a ConcurrentLinkedQueue here, because its Iterator is weakly     * consistent and we want {@link #invokePacketCollectors(Stanza)} for-each     * loop to be lock free. As drawback, removing a PacketCollector is O(n).     * The alternative would be a synchronized HashSet, but this would mean a     * synchronized block around every usage of <code>collectors</code>.     * </p>     */    private final Collection<PacketCollector> collectors = new ConcurrentLinkedQueue<PacketCollector>();    /**     * List of PacketListeners that will be notified synchronously when a new stanza(/packet) was received.     */    private final Map<StanzaListener, ListenerWrapper> syncRecvListeners = new LinkedHashMap<>();    /**     * List of PacketListeners that will be notified asynchronously when a new stanza(/packet) was received.     */    private final Map<StanzaListener, ListenerWrapper> asyncRecvListeners = new LinkedHashMap<>();    /**     * List of PacketListeners that will be notified when a new stanza(/packet) was sent.     */    private final Map<StanzaListener, ListenerWrapper> sendListeners =            new HashMap<StanzaListener, ListenerWrapper>();    /**     * List of PacketListeners that will be notified when a new stanza(/packet) is about to be     * sent to the server. These interceptors may modify the stanza(/packet) before it is being     * actually sent to the server.     */    private final Map<StanzaListener, InterceptorWrapper> interceptors =            new HashMap<StanzaListener, InterceptorWrapper>();    protected final Lock connectionLock = new ReentrantLock();    protected final Map<String, ExtensionElement> streamFeatures = new HashMap<String, ExtensionElement>();    /**     * The full JID of the authenticated user, as returned by the resource binding response of the server.     * <p>     * It is important that we don't infer the user from the login() arguments and the configurations service name, as,     * for example, when SASL External is used, the username is not given to login but taken from the 'external'     * certificate.     * </p>     */    protected String user;    protected boolean connected = false;    /**     * The stream ID, see RFC 6120 § 4.7.3     */    protected String streamId;    /**     *      */    private long packetReplyTimeout = SmackConfiguration.getDefaultPacketReplyTimeout();    /**     * The SmackDebugger allows to log and debug XML traffic.     */    protected SmackDebugger debugger = null;    /**     * The Reader which is used for the debugger.     */    protected Reader reader;    /**     * The Writer which is used for the debugger.     */    protected Writer writer;    /**     * Set to success if the last features stanza from the server has been parsed. A XMPP connection     * handshake can invoke multiple features stanzas, e.g. when TLS is activated a second feature     * stanza is send by the server. This is set to true once the last feature stanza has been     * parsed.     */    protected final SynchronizationPoint<Exception> lastFeaturesReceived = new SynchronizationPoint<Exception>(                    AbstractXMPPConnection.this);    /**     * Set to success if the sasl feature has been received.     */    protected final SynchronizationPoint<SmackException> saslFeatureReceived = new SynchronizationPoint<SmackException>(                    AbstractXMPPConnection.this);     /**     * The SASLAuthentication manager that is responsible for authenticating with the server.     */    protected SASLAuthentication saslAuthentication = new SASLAuthentication(this);    /**     * A number to uniquely identify connections that are created. This is distinct from the     * connection ID, which is a value sent by the server once a connection is made.     */    protected final int connectionCounterValue = connectionCounter.getAndIncrement();    /**     * Holds the initial configuration used while creating the connection.     */    protected final ConnectionConfiguration config;    /**     * Defines how the from attribute of outgoing stanzas should be handled.     */    private FromMode fromMode = FromMode.OMITTED;    protected XMPPInputOutputStream compressionHandler;    private ParsingExceptionCallback parsingExceptionCallback = SmackConfiguration.getDefaultParsingExceptionCallback();    /**     * ExecutorService used to invoke the PacketListeners on newly arrived and parsed stanzas. It is     * important that we use a <b>single threaded ExecutorService</b> in order to guarantee that the     * PacketListeners are invoked in the same order the stanzas arrived.     */    private final BoundedThreadPoolExecutor executorService = new BoundedThreadPoolExecutor(1, 1, 0, TimeUnit.SECONDS,                    100, new SmackExecutorThreadFactory(connectionCounterValue, "Incoming Processor"));    /**     * This scheduled thread pool executor is used to remove pending callbacks.     */    private final ScheduledExecutorService removeCallbacksService = Executors.newSingleThreadScheduledExecutor(                    new SmackExecutorThreadFactory(connectionCounterValue, "Remove Callbacks"));    /**     * A cached thread pool executor service with custom thread factory to set meaningful names on the threads and set     * them 'daemon'.     */    private final ExecutorService cachedExecutorService = Executors.newCachedThreadPool(                    // @formatter:off                    new SmackExecutorThreadFactory(    // threadFactory                                    connectionCounterValue,                                    "Cached Executor"                                    )                    // @formatter:on                    );    /**     * A executor service used to invoke the callbacks of synchronous stanza(/packet) listeners. We use a executor service to     * decouple incoming stanza processing from callback invocation. It is important that order of callback invocation     * is the same as the order of the incoming stanzas. Therefore we use a <i>single</i> threaded executor service.     */    private final ExecutorService singleThreadedExecutorService = Executors.newSingleThreadExecutor(new SmackExecutorThreadFactory(                    getConnectionCounter(), "Single Threaded Executor"));    /**     * The used host to establish the connection to     */    protected String host;    /**     * The used port to establish the connection to     */    protected int port;    /**     * Flag that indicates if the user is currently authenticated with the server.     */    protected boolean authenticated = false;    /**     * Flag that indicates if the user was authenticated with the server when the connection     * to the server was closed (abruptly or not).     */    protected boolean wasAuthenticated = false;    private final Map<String, IQRequestHandler> setIqRequestHandler = new HashMap<>();    private final Map<String, IQRequestHandler> getIqRequestHandler = new HashMap<>();    /**     * Create a new XMPPConnection to an XMPP server.     *      * @param configuration The configuration which is used to establish the connection.     */    protected AbstractXMPPConnection(ConnectionConfiguration configuration) {        config = configuration;    }    /**     * Get the connection configuration used by this connection.     *     * @return the connection configuration.     */    public ConnectionConfiguration getConfiguration() {        return config;    }    @Override    public String getServiceName() {        if (serviceName != null) {            return serviceName;        }        return config.getServiceName();    }    @Override    public String getHost() {        return host;    }    @Override    public int getPort() {        return port;    }    @Override    public abstract boolean isSecureConnection();    protected abstract void sendStanzaInternal(Stanza packet) throws NotConnectedException;    @Override    public abstract void send(PlainStreamElement element) throws NotConnectedException;    @Override    public abstract boolean isUsingCompression();    /**     * Establishes a connection to the XMPP server and performs an automatic login     * only if the previous connection state was logged (authenticated). It basically     * creates and maintains a connection to the server.     * <p>     * Listeners will be preserved from a previous connection.     *      * @throws XMPPException if an error occurs on the XMPP protocol level.     * @throws SmackException if an error occurs somewhere else besides XMPP protocol level.     * @throws IOException      * @throws ConnectionException with detailed information about the failed connection.     * @return a reference to this object, to chain <code>connect()</code> with <code>login()</code>.     */    public synchronized AbstractXMPPConnection connect() throws SmackException, IOException, XMPPException {        // Check if not already connected        throwAlreadyConnectedExceptionIfAppropriate();        // Reset the connection state        saslAuthentication.init();        saslFeatureReceived.init();        lastFeaturesReceived.init();        streamId = null;        // Perform the actual connection to the XMPP service        connectInternal();        return this;    }    /**     * Abstract method that concrete subclasses of XMPPConnection need to implement to perform their     * way of XMPP connection establishment. Implementations are required to perform an automatic     * login if the previous connection state was logged (authenticated).     *      * @throws SmackException     * @throws IOException     * @throws XMPPException     */    protected abstract void connectInternal() throws SmackException, IOException, XMPPException;    private String usedUsername, usedPassword, usedResource;    /**     * Logs in to the server using the strongest SASL mechanism supported by     * the server. If more than the connection's default stanza(/packet) timeout elapses in each step of the      * authentication process without a response from the server, a     * {@link SmackException.NoResponseException} will be thrown.     * <p>     * Before logging in (i.e. authenticate) to the server the connection must be connected     * by calling {@link #connect}.     * </p>     * <p>     * It is possible to log in without sending an initial available presence by using     * {@link ConnectionConfiguration.Builder#setSendPresence(boolean)}.     * Finally, if you want to not pass a password and instead use a more advanced mechanism     * while using SASL then you may be interested in using     * {@link ConnectionConfiguration.Builder#setCallbackHandler(javax.security.auth.callback.CallbackHandler)}.     * For more advanced login settings see {@link ConnectionConfiguration}.     * </p>     *      * @throws XMPPException if an error occurs on the XMPP protocol level.     * @throws SmackException if an error occurs somewhere else besides XMPP protocol level.     * @throws IOException if an I/O error occurs during login.     */    public synchronized void login() throws XMPPException, SmackException, IOException {        if (isAnonymous()) {            throwNotConnectedExceptionIfAppropriate("Did you call connect() before login()?");            throwAlreadyLoggedInExceptionIfAppropriate();            loginAnonymously();        } else {            // The previously used username, password and resource take over precedence over the            // ones from the connection configuration            CharSequence username = usedUsername != null ? usedUsername : config.getUsername();            String password = usedPassword != null ? usedPassword : config.getPassword();            String resource = usedResource != null ? usedResource : config.getResource();            login(username, password, resource);        }    }    /**     * Same as {@link #login(CharSequence, String, String)}, but takes the resource from the connection     * configuration.     *      * @param username     * @param password     * @throws XMPPException     * @throws SmackException     * @throws IOException     * @see #login     */    public synchronized void login(CharSequence username, String password) throws XMPPException, SmackException,                    IOException {        login(username, password, config.getResource());    }    /**     * Login with the given username (authorization identity). You may omit the password if a callback handler is used.     * If resource is null, then the server will generate one.     *      * @param username     * @param password     * @param resource     * @throws XMPPException     * @throws SmackException     * @throws IOException     * @see #login     */    public synchronized void login(CharSequence username, String password, String resource) throws XMPPException,                    SmackException, IOException {        if (!config.allowNullOrEmptyUsername) {            StringUtils.requireNotNullOrEmpty(username, "Username must not be null or empty");        }        throwNotConnectedExceptionIfAppropriate();        throwAlreadyLoggedInExceptionIfAppropriate();        usedUsername = username != null ? username.toString() : null;        usedPassword = password;        usedResource = resource;        loginNonAnonymously(usedUsername, usedPassword, usedResource);    }    protected abstract void loginNonAnonymously(String username, String password, String resource)                    throws XMPPException, SmackException, IOException;    protected abstract void loginAnonymously() throws XMPPException, SmackException, IOException;    @Override    public final boolean isConnected() {        return connected;    }    @Override    public final boolean isAuthenticated() {        return authenticated;    }    @Override    public final String getUser() {        return user;    }    @Override    public String getStreamId() {        if (!isConnected()) {            return null;        }        return streamId;    }    // TODO remove this suppression once "disable legacy session" code has been removed from Smack    @SuppressWarnings("deprecation")    protected void bindResourceAndEstablishSession(String resource) throws XMPPErrorException,                    IOException, SmackException {        // Wait until either:        // - the servers last features stanza has been parsed        // - the timeout occurs        LOGGER.finer("Waiting for last features to be received before continuing with resource binding");        lastFeaturesReceived.checkIfSuccessOrWait();        if (!hasFeature(Bind.ELEMENT, Bind.NAMESPACE)) {            // Server never offered resource binding, which is REQURIED in XMPP client and            // server implementations as per RFC6120 7.2            throw new ResourceBindingNotOfferedException();        }        // Resource binding, see RFC6120 7.        // Note that we can not use IQReplyFilter here, since the users full JID is not yet        // available. It will become available right after the resource has been successfully bound.        Bind bindResource = Bind.newSet(resource);        PacketCollector packetCollector = createPacketCollectorAndSend(new StanzaIdFilter(bindResource), bindResource);        Bind response = packetCollector.nextResultOrThrow();        // Set the connections user to the result of resource binding. It is important that we don't infer the user        // from the login() arguments and the configurations service name, as, for example, when SASL External is used,        // the username is not given to login but taken from the 'external' certificate.        user = response.getJid();        serviceName = XmppStringUtils.parseDomain(user);        Session.Feature sessionFeature = getFeature(Session.ELEMENT, Session.NAMESPACE);        // Only bind the session if it's announced as stream feature by the server, is not optional and not disabled        // For more information see http://tools.ietf.org/html/draft-cridland-xmpp-session-01        if (sessionFeature != null && !sessionFeature.isOptional() && !getConfiguration().isLegacySessionDisabled()) {            Session session = new Session();            packetCollector = createPacketCollectorAndSend(new StanzaIdFilter(session), session);            packetCollector.nextResultOrThrow();        }    }    protected void afterSuccessfulLogin(final boolean resumed) throws NotConnectedException {        // Indicate that we're now authenticated.        this.authenticated = true;        // If debugging is enabled, change the the debug window title to include the        // name we are now logged-in as.        // If DEBUG was set to true AFTER the connection was created the debugger        // will be null        if (config.isDebuggerEnabled() && debugger != null) {            debugger.userHasLogged(user);        }        callConnectionAuthenticatedListener(resumed);        // Set presence to online. It is important that this is done after        // callConnectionAuthenticatedListener(), as this call will also        // eventually load the roster. And we should load the roster before we        // send the initial presence.        if (config.isSendPresence() && !resumed) {            sendStanza(new Presence(Presence.Type.available));        }    }    @Override    public final boolean isAnonymous() {        return config.getUsername() == null && usedUsername == null                        && !config.allowNullOrEmptyUsername;    }    private String serviceName;    protected List<HostAddress> hostAddresses;    /**     * Populates {@link #hostAddresses} with at least one host address.     *     * @return a list of host addresses where DNS (SRV) RR resolution failed.     */    protected List<HostAddress> populateHostAddresses() {        List<HostAddress> failedAddresses = new LinkedList<>();        // N.B.: Important to use config.serviceName and not AbstractXMPPConnection.serviceName        if (config.host != null) {            hostAddresses = new ArrayList<HostAddress>(1);            HostAddress hostAddress;            hostAddress = new HostAddress(config.host, config.port);            hostAddresses.add(hostAddress);        } else {            hostAddresses = DNSUtil.resolveXMPPDomain(config.serviceName, failedAddresses);        }        // If we reach this, then hostAddresses *must not* be empty, i.e. there is at least one host added, either the        // config.host one or the host representing the service name by DNSUtil        assert(!hostAddresses.isEmpty());        return failedAddresses;    }    protected Lock getConnectionLock() {        return connectionLock;    }    protected void throwNotConnectedExceptionIfAppropriate() throws NotConnectedException {        throwNotConnectedExceptionIfAppropriate(null);    }    protected void throwNotConnectedExceptionIfAppropriate(String optionalHint) throws NotConnectedException {        if (!isConnected()) {            throw new NotConnectedException(optionalHint);        }    }    protected void throwAlreadyConnectedExceptionIfAppropriate() throws AlreadyConnectedException {        if (isConnected()) {            throw new AlreadyConnectedException();        }    }    protected void throwAlreadyLoggedInExceptionIfAppropriate() throws AlreadyLoggedInException {        if (isAuthenticated()) {            throw new AlreadyLoggedInException();        }    }    @Deprecated    @Override    public void sendPacket(Stanza packet) throws NotConnectedException {        sendStanza(packet);    }    @Override    public void sendStanza(Stanza packet) throws NotConnectedException {        Objects.requireNonNull(packet, "Packet must not be null");        throwNotConnectedExceptionIfAppropriate();        switch (fromMode) {        case OMITTED:            packet.setFrom(null);            break;        case USER:            packet.setFrom(getUser());            break;        case UNCHANGED:        default:            break;        }        // Invoke interceptors for the new packet that is about to be sent. Interceptors may modify        // the content of the packet.        firePacketInterceptors(packet);        sendStanzaInternal(packet);    }    /**     * Returns the SASLAuthentication manager that is responsible for authenticating with     * the server.     *      * @return the SASLAuthentication manager that is responsible for authenticating with     *         the server.     */    protected SASLAuthentication getSASLAuthentication() {        return saslAuthentication;    }    /**     * Closes the connection by setting presence to unavailable then closing the connection to     * the XMPP server. The XMPPConnection can still be used for connecting to the server     * again.     *     */    public void disconnect() {        try {            disconnect(new Presence(Presence.Type.unavailable));        }        catch (NotConnectedException e) {            LOGGER.log(Level.FINEST, "Connection is already disconnected", e);        }    }    /**     * Closes the connection. A custom unavailable presence is sent to the server, followed     * by closing the stream. The XMPPConnection can still be used for connecting to the server     * again. A custom unavailable presence is useful for communicating offline presence     * information such as "On vacation". Typically, just the status text of the presence     * stanza(/packet) is set with online information, but most XMPP servers will deliver the full     * presence stanza(/packet) with whatever data is set.     *      * @param unavailablePresence the presence stanza(/packet) to send during shutdown.     * @throws NotConnectedException      */    public synchronized void disconnect(Presence unavailablePresence) throws NotConnectedException {        sendStanza(unavailablePresence);        shutdown();        callConnectionClosedListener();    }    /**     * Shuts the current connection down.     */    protected abstract void shutdown();    @Override    public void addConnectionListener(ConnectionListener connectionListener) {        if (connectionListener == null) {            return;        }        connectionListeners.add(connectionListener);    }    @Override    public void removeConnectionListener(ConnectionListener connectionListener) {        connectionListeners.remove(connectionListener);    }    @Override    public PacketCollector createPacketCollectorAndSend(IQ packet) throws NotConnectedException {        StanzaFilter packetFilter = new IQReplyFilter(packet, this);        // Create the packet collector before sending the packet        PacketCollector packetCollector = createPacketCollectorAndSend(packetFilter, packet);        return packetCollector;    }    @Override    public PacketCollector createPacketCollectorAndSend(StanzaFilter packetFilter, Stanza packet)                    throws NotConnectedException {        // Create the packet collector before sending the packet        PacketCollector packetCollector = createPacketCollector(packetFilter);        try {            // Now we can send the packet as the collector has been created            sendStanza(packet);        }        catch (NotConnectedException | RuntimeException e) {            packetCollector.cancel();            throw e;        }        return packetCollector;    }    @Override    public PacketCollector createPacketCollector(StanzaFilter packetFilter) {        PacketCollector.Configuration configuration = PacketCollector.newConfiguration().setStanzaFilter(packetFilter);        return createPacketCollector(configuration);    }    @Override    public PacketCollector createPacketCollector(PacketCollector.Configuration configuration) {        PacketCollector collector = new PacketCollector(this, configuration);        // Add the collector to the list of active collectors.        collectors.add(collector);        return collector;    }    @Override    public void removePacketCollector(PacketCollector collector) {        collectors.remove(collector);    }    @Override    @Deprecated    public void addPacketListener(StanzaListener packetListener, StanzaFilter packetFilter) {        addAsyncStanzaListener(packetListener, packetFilter);    }    @Override    @Deprecated    public boolean removePacketListener(StanzaListener packetListener) {        return removeAsyncStanzaListener(packetListener);    }    @Override    public void addSyncStanzaListener(StanzaListener packetListener, StanzaFilter packetFilter) {        if (packetListener == null) {            throw new NullPointerException("Packet listener is null.");        }        ListenerWrapper wrapper = new ListenerWrapper(packetListener, packetFilter);        synchronized (syncRecvListeners) {            syncRecvListeners.put(packetListener, wrapper);        }    }    @Override    public boolean removeSyncStanzaListener(StanzaListener packetListener) {        synchronized (syncRecvListeners) {            return syncRecvListeners.remove(packetListener) != null;        }    }    @Override    public void addAsyncStanzaListener(StanzaListener packetListener, StanzaFilter packetFilter) {        if (packetListener == null) {            throw new NullPointerException("Packet listener is null.");        }        ListenerWrapper wrapper = new ListenerWrapper(packetListener, packetFilter);        synchronized (asyncRecvListeners) {            asyncRecvListeners.put(packetListener, wrapper);        }    }    @Override    public boolean removeAsyncStanzaListener(StanzaListener packetListener) {        synchronized (asyncRecvListeners) {            return asyncRecvListeners.remove(packetListener) != null;        }    }    @Override    public void addPacketSendingListener(StanzaListener packetListener, StanzaFilter packetFilter) {        if (packetListener == null) {            throw new NullPointerException("Packet listener is null.");        }        ListenerWrapper wrapper = new ListenerWrapper(packetListener, packetFilter);        synchronized (sendListeners) {            sendListeners.put(packetListener, wrapper);        }    }    @Override    public void removePacketSendingListener(StanzaListener packetListener) {        synchronized (sendListeners) {            sendListeners.remove(packetListener);        }    }    /**     * Process all stanza(/packet) listeners for sending packets.     * <p>     * Compared to {@link #firePacketInterceptors(Stanza)}, the listeners will be invoked in a new thread.     * </p>     *      * @param packet the stanza(/packet) to process.     */    @SuppressWarnings("javadoc")    protected void firePacketSendingListeners(final Stanza packet) {        final List<StanzaListener> listenersToNotify = new LinkedList<StanzaListener>();        synchronized (sendListeners) {            for (ListenerWrapper listenerWrapper : sendListeners.values()) {                if (listenerWrapper.filterMatches(packet)) {                    listenersToNotify.add(listenerWrapper.getListener());                }            }        }        if (listenersToNotify.isEmpty()) {            return;        }        // Notify in a new thread, because we can        asyncGo(new Runnable() {            @Override            public void run() {                for (StanzaListener listener : listenersToNotify) {                    try {                        listener.processPacket(packet);                    }                    catch (Exception e) {                        LOGGER.log(Level.WARNING, "Sending listener threw exception", e);                        continue;                    }                }            }});    }    @Override    public void addPacketInterceptor(StanzaListener packetInterceptor,            StanzaFilter packetFilter) {        if (packetInterceptor == null) {            throw new NullPointerException("Packet interceptor is null.");        }        InterceptorWrapper interceptorWrapper = new InterceptorWrapper(packetInterceptor, packetFilter);        synchronized (interceptors) {            interceptors.put(packetInterceptor, interceptorWrapper);        }    }    @Override    public void removePacketInterceptor(StanzaListener packetInterceptor) {        synchronized (interceptors) {            interceptors.remove(packetInterceptor);        }    }    /**     * Process interceptors. Interceptors may modify the stanza(/packet) that is about to be sent.     * Since the thread that requested to send the stanza(/packet) will invoke all interceptors, it     * is important that interceptors perform their work as soon as possible so that the     * thread does not remain blocked for a long period.     *      * @param packet the stanza(/packet) that is going to be sent to the server     */    private void firePacketInterceptors(Stanza packet) {        List<StanzaListener> interceptorsToInvoke = new LinkedList<StanzaListener>();        synchronized (interceptors) {            for (InterceptorWrapper interceptorWrapper : interceptors.values()) {                if (interceptorWrapper.filterMatches(packet)) {                    interceptorsToInvoke.add(interceptorWrapper.getInterceptor());                }            }        }        for (StanzaListener interceptor : interceptorsToInvoke) {            try {                interceptor.processPacket(packet);            } catch (Exception e) {                LOGGER.log(Level.SEVERE, "Packet interceptor threw exception", e);            }        }    }    /**     * Initialize the {@link #debugger}. You can specify a customized {@link SmackDebugger}     * by setup the system property <code>smack.debuggerClass</code> to the implementation.     *      * @throws IllegalStateException if the reader or writer isn't yet initialized.     * @throws IllegalArgumentException if the SmackDebugger can't be loaded.     */    protected void initDebugger() {        if (reader == null || writer == null) {            throw new NullPointerException("Reader or writer isn't initialized.");        }        // If debugging is enabled, we open a window and write out all network traffic.        if (config.isDebuggerEnabled()) {            if (debugger == null) {                debugger = SmackConfiguration.createDebugger(this, writer, reader);            }            if (debugger == null) {                LOGGER.severe("Debugging enabled but could not find debugger class");            } else {                // Obtain new reader and writer from the existing debugger                reader = debugger.newConnectionReader(reader);                writer = debugger.newConnectionWriter(writer);            }        }    }    @Override    public long getPacketReplyTimeout() {        return packetReplyTimeout;    }    @Override    public void setPacketReplyTimeout(long timeout) {        packetReplyTimeout = timeout;    }    private static boolean replyToUnknownIqDefault = true;    /**     * Set the default value used to determine if new connection will reply to unknown IQ requests. The pre-configured     * default is 'true'.     *     * @param replyToUnkownIqDefault     * @see #setReplyToUnknownIq(boolean)     */    public static void setReplyToUnknownIqDefault(boolean replyToUnkownIqDefault) {        AbstractXMPPConnection.replyToUnknownIqDefault = replyToUnkownIqDefault;    }    private boolean replyToUnkownIq = replyToUnknownIqDefault;    /**     * Set if Smack will automatically send     * {@link org.jivesoftware.smack.packet.XMPPError.Condition#feature_not_implemented} when a request IQ without a     * registered {@link IQRequestHandler} is received.     *     * @param replyToUnknownIq     */    public void setReplyToUnknownIq(boolean replyToUnknownIq) {        this.replyToUnkownIq = replyToUnknownIq;    }    protected void parseAndProcessStanza(XmlPullParser parser) throws Exception {        ParserUtils.assertAtStartTag(parser);        int parserDepth = parser.getDepth();        Stanza stanza = null;        try {            stanza = PacketParserUtils.parseStanza(parser);        }        catch (Exception e) {            CharSequence content = PacketParserUtils.parseContentDepth(parser,                            parserDepth);            UnparsablePacket message = new UnparsablePacket(content, e);            ParsingExceptionCallback callback = getParsingExceptionCallback();            if (callback != null) {                callback.handleUnparsablePacket(message);            }        }        ParserUtils.assertAtEndTag(parser);        if (stanza != null) {            processPacket(stanza);        }    }    /**     * Processes a stanza(/packet) after it's been fully parsed by looping through the installed     * stanza(/packet) collectors and listeners and letting them examine the stanza(/packet) to see if     * they are a match with the filter.     *     * @param packet the stanza(/packet) to process.     * @throws InterruptedException     */    protected void processPacket(Stanza packet) throws InterruptedException {        assert(packet != null);        lastStanzaReceived = System.currentTimeMillis();        // Deliver the incoming packet to listeners.        executorService.executeBlocking(new ListenerNotification(packet));    }    /**     * A runnable to notify all listeners and stanza(/packet) collectors of a packet.     */    private class ListenerNotification implements Runnable {        private final Stanza packet;        public ListenerNotification(Stanza packet) {            this.packet = packet;        }        public void run() {            invokePacketCollectorsAndNotifyRecvListeners(packet);        }    }    /**     * Invoke {@link PacketCollector#processPacket(Stanza)} for every     * PacketCollector with the given packet. Also notify the receive listeners with a matching stanza(/packet) filter about the packet.     *     * @param packet the stanza(/packet) to notify the PacketCollectors and receive listeners about.     */    protected void invokePacketCollectorsAndNotifyRecvListeners(final Stanza packet) {        if (packet instanceof IQ) {            final IQ iq = (IQ) packet;            final IQ.Type type = iq.getType();            switch (type) {            case set:            case get:                final String key = XmppStringUtils.generateKey(iq.getChildElementName(), iq.getChildElementNamespace());                IQRequestHandler iqRequestHandler = null;                switch (type) {                case set:                    synchronized (setIqRequestHandler) {                        iqRequestHandler = setIqRequestHandler.get(key);                    }                    break;                case get:                    synchronized (getIqRequestHandler) {                        iqRequestHandler = getIqRequestHandler.get(key);                    }                    break;                default:                    throw new IllegalStateException("Should only encounter IQ type 'get' or 'set'");                }                if (iqRequestHandler == null) {                    if (!replyToUnkownIq) {                        return;                    }                    // If the IQ stanza is of type "get" or "set" with no registered IQ request handler, then answer an                    // IQ of type "error" with code 501 ("feature-not-implemented")                    ErrorIQ errorIQ = IQ.createErrorResponse(iq, new XMPPError(                                    XMPPError.Condition.feature_not_implemented));                    try {                        sendStanza(errorIQ);                    }                    catch (NotConnectedException e) {                        LOGGER.log(Level.WARNING, "NotConnectedException while sending error IQ to unkown IQ request", e);                    }                } else {                    ExecutorService executorService = null;                    switch (iqRequestHandler.getMode()) {                    case sync:                        executorService = singleThreadedExecutorService;                        break;                    case async:                        executorService = cachedExecutorService;                        break;                    }                    final IQRequestHandler finalIqRequestHandler = iqRequestHandler;                    executorService.execute(new Runnable() {                        @Override                        public void run() {                            IQ response = finalIqRequestHandler.handleIQRequest(iq);                            if (response == null) {                                // It is not ideal if the IQ request handler does not return an IQ response, because RFC                                // 6120 § 8.1.2 does specify that a response is mandatory. But some APIs, mostly the                                // file transfer one, does not always return a result, so we need to handle this case.                                // Also sometimes a request handler may decide that it's better to not send a response,                                // e.g. to avoid presence leaks.                                return;                            }                            try {                                sendStanza(response);                            }                            catch (NotConnectedException e) {                                LOGGER.log(Level.WARNING, "NotConnectedException while sending response to IQ request", e);                            }                        }                    });                    // The following returns makes it impossible for packet listeners and collectors to                    // filter for IQ request stanzas, i.e. IQs of type 'set' or 'get'. This is the                    // desired behavior.                    return;                }                break;            default:                break;            }        }        // First handle the async recv listeners. Note that this code is very similar to what follows a few lines below,        // the only difference is that asyncRecvListeners is used here and that the packet listeners are started in        // their own thread.        final Collection<StanzaListener> listenersToNotify = new LinkedList<StanzaListener>();        synchronized (asyncRecvListeners) {            for (ListenerWrapper listenerWrapper : asyncRecvListeners.values()) {                if (listenerWrapper.filterMatches(packet)) {                    listenersToNotify.add(listenerWrapper.getListener());                }            }        }        for (final StanzaListener listener : listenersToNotify) {            asyncGo(new Runnable() {                @Override                public void run() {                    try {                        listener.processPacket(packet);                    } catch (Exception e) {                        LOGGER.log(Level.SEVERE, "Exception in async packet listener", e);                    }                }            });        }        // Loop through all collectors and notify the appropriate ones.        for (PacketCollector collector: collectors) {            collector.processPacket(packet);        }        // Notify the receive listeners interested in the packet        listenersToNotify.clear();        synchronized (syncRecvListeners) {            for (ListenerWrapper listenerWrapper : syncRecvListeners.values()) {                if (listenerWrapper.filterMatches(packet)) {                    listenersToNotify.add(listenerWrapper.getListener());                }            }        }        // Decouple incoming stanza processing from listener invocation. Unlike async listeners, this uses a single        // threaded executor service and therefore keeps the order.        singleThreadedExecutorService.execute(new Runnable() {            @Override            public void run() {                for (StanzaListener listener : listenersToNotify) {                    try {                        listener.processPacket(packet);                    } catch(NotConnectedException e) {                        LOGGER.log(Level.WARNING, "Got not connected exception, aborting", e);                        break;                    } catch (Exception e) {                        LOGGER.log(Level.SEVERE, "Exception in packet listener", e);                    }                }            }        });    }    /**     * Sets whether the connection has already logged in the server. This method assures that the     * {@link #wasAuthenticated} flag is never reset once it has ever been set.     *      */    protected void setWasAuthenticated() {        // Never reset the flag if the connection has ever been authenticated        if (!wasAuthenticated) {            wasAuthenticated = authenticated;        }    }    protected void callConnectionConnectedListener() {        for (ConnectionListener listener : connectionListeners) {            listener.connected(this);        }    }    protected void callConnectionAuthenticatedListener(boolean resumed) {        for (ConnectionListener listener : connectionListeners) {            try {                listener.authenticated(this, resumed);            } catch (Exception e) {                // Catch and print any exception so we can recover                // from a faulty listener and finish the shutdown process                LOGGER.log(Level.SEVERE, "Exception in authenticated listener", e);            }        }    }    void callConnectionClosedListener() {        for (ConnectionListener listener : connectionListeners) {            try {                listener.connectionClosed();            }            catch (Exception e) {                // Catch and print any exception so we can recover                // from a faulty listener and finish the shutdown process                LOGGER.log(Level.SEVERE, "Error in listener while closing connection", e);            }        }    }    protected void callConnectionClosedOnErrorListener(Exception e) {        LOGGER.log(Level.WARNING, "Connection closed with error", e);        for (ConnectionListener listener : connectionListeners) {            try {                listener.connectionClosedOnError(e);            }            catch (Exception e2) {                // Catch and print any exception so we can recover                // from a faulty listener                LOGGER.log(Level.SEVERE, "Error in listener while closing connection", e2);            }        }    }    /**     * Sends a notification indicating that the connection was reconnected successfully.     */    protected void notifyReconnection() {        // Notify connection listeners of the reconnection.        for (ConnectionListener listener : connectionListeners) {            try {                listener.reconnectionSuccessful();            }            catch (Exception e) {                // Catch and print any exception so we can recover                // from a faulty listener                LOGGER.log(Level.WARNING, "notifyReconnection()", e);            }        }    }    /**     * A wrapper class to associate a stanza(/packet) filter with a listener.     */    protected static class ListenerWrapper {        private final StanzaListener packetListener;        private final StanzaFilter packetFilter;        /**         * Create a class which associates a stanza(/packet) filter with a listener.         *          * @param packetListener the stanza(/packet) listener.         * @param packetFilter the associated filter or null if it listen for all packets.         */        public ListenerWrapper(StanzaListener packetListener, StanzaFilter packetFilter) {            this.packetListener = packetListener;            this.packetFilter = packetFilter;        }        public boolean filterMatches(Stanza packet) {            return packetFilter == null || packetFilter.accept(packet);        }        public StanzaListener getListener() {            return packetListener;        }    }    /**     * A wrapper class to associate a stanza(/packet) filter with an interceptor.     */    protected static class InterceptorWrapper {        private final StanzaListener packetInterceptor;        private final StanzaFilter packetFilter;        /**         * Create a class which associates a stanza(/packet) filter with an interceptor.         *          * @param packetInterceptor the interceptor.         * @param packetFilter the associated filter or null if it intercepts all packets.         */        public InterceptorWrapper(StanzaListener packetInterceptor, StanzaFilter packetFilter) {            this.packetInterceptor = packetInterceptor;            this.packetFilter = packetFilter;        }        public boolean filterMatches(Stanza packet) {            return packetFilter == null || packetFilter.accept(packet);        }        public StanzaListener getInterceptor() {            return packetInterceptor;        }    }    @Override    public int getConnectionCounter() {        return connectionCounterValue;    }    @Override    public void setFromMode(FromMode fromMode) {        this.fromMode = fromMode;    }    @Override    public FromMode getFromMode() {        return this.fromMode;    }    @Override    protected void finalize() throws Throwable {        LOGGER.fine("finalizing XMPPConnection ( " + getConnectionCounter()                        + "): Shutting down executor services");        try {            // It's usually not a good idea to rely on finalize. But this is the easiest way to            // avoid the "Smack Listener Processor" leaking. The thread(s) of the executor have a            // reference to their ExecutorService which prevents the ExecutorService from being            // gc'ed. It is possible that the XMPPConnection instance is gc'ed while the            // listenerExecutor ExecutorService call not be gc'ed until it got shut down.            executorService.shutdownNow();            cachedExecutorService.shutdown();            removeCallbacksService.shutdownNow();            singleThreadedExecutorService.shutdownNow();        } catch (Throwable t) {            LOGGER.log(Level.WARNING, "finalize() threw trhowable", t);        }        finally {            super.finalize();        }    }    protected final void parseFeatures(XmlPullParser parser) throws XmlPullParserException,                    IOException, SmackException {        streamFeatures.clear();        final int initialDepth = parser.getDepth();        while (true) {            int eventType = parser.next();            if (eventType == XmlPullParser.START_TAG && parser.getDepth() == initialDepth + 1) {                ExtensionElement streamFeature = null;                String name = parser.getName();                String namespace = parser.getNamespace();                switch (name) {                case StartTls.ELEMENT:                    streamFeature = PacketParserUtils.parseStartTlsFeature(parser);                    break;                case Mechanisms.ELEMENT:                    streamFeature = new Mechanisms(PacketParserUtils.parseMechanisms(parser));                    break;                case Bind.ELEMENT:                    streamFeature = Bind.Feature.INSTANCE;                    break;                case Session.ELEMENT:                    streamFeature = PacketParserUtils.parseSessionFeature(parser);                    break;                case Compress.Feature.ELEMENT:                    streamFeature = PacketParserUtils.parseCompressionFeature(parser);                    break;                default:                    ExtensionElementProvider<ExtensionElement> provider = ProviderManager.getStreamFeatureProvider(name, namespace);                    if (provider != null) {                        streamFeature = provider.parse(parser);                    }                    break;                }                if (streamFeature != null) {                    addStreamFeature(streamFeature);                }            }            else if (eventType == XmlPullParser.END_TAG && parser.getDepth() == initialDepth) {                break;            }        }        if (hasFeature(Mechanisms.ELEMENT, Mechanisms.NAMESPACE)) {            // Only proceed with SASL auth if TLS is disabled or if the server doesn't announce it            if (!hasFeature(StartTls.ELEMENT, StartTls.NAMESPACE)                            || config.getSecurityMode() == SecurityMode.disabled) {                saslFeatureReceived.reportSuccess();            }        }        // If the server reported the bind feature then we are that that we did SASL and maybe        // STARTTLS. We can then report that the last 'stream:features' have been parsed        if (hasFeature(Bind.ELEMENT, Bind.NAMESPACE)) {            if (!hasFeature(Compress.Feature.ELEMENT, Compress.NAMESPACE)                            || !config.isCompressionEnabled()) {                // This was was last features from the server is either it did not contain                // compression or if we disabled it                lastFeaturesReceived.reportSuccess();            }        }        afterFeaturesReceived();    }    protected void afterFeaturesReceived() throws SecurityRequiredException, NotConnectedException {        // Default implementation does nothing    }    @SuppressWarnings("unchecked")    @Override    public <F extends ExtensionElement> F getFeature(String element, String namespace) {        return (F) streamFeatures.get(XmppStringUtils.generateKey(element, namespace));    }    @Override    public boolean hasFeature(String element, String namespace) {        return getFeature(element, namespace) != null;    }    private void addStreamFeature(ExtensionElement feature) {        String key = XmppStringUtils.generateKey(feature.getElementName(), feature.getNamespace());        streamFeatures.put(key, feature);    }    @Override    public void sendStanzaWithResponseCallback(Stanza stanza, StanzaFilter replyFilter,                    StanzaListener callback) throws NotConnectedException {        sendStanzaWithResponseCallback(stanza, replyFilter, callback, null);    }    @Override    public void sendStanzaWithResponseCallback(Stanza stanza, StanzaFilter replyFilter,                    StanzaListener callback, ExceptionCallback exceptionCallback)                    throws NotConnectedException {        sendStanzaWithResponseCallback(stanza, replyFilter, callback, exceptionCallback,                        getPacketReplyTimeout());    }    @Override    public void sendStanzaWithResponseCallback(Stanza stanza, final StanzaFilter replyFilter,                    final StanzaListener callback, final ExceptionCallback exceptionCallback,                    long timeout) throws NotConnectedException {        Objects.requireNonNull(stanza, "stanza must not be null");        // While Smack allows to add PacketListeners with a PacketFilter value of 'null', we        // disallow it here in the async API as it makes no sense        Objects.requireNonNull(replyFilter, "replyFilter must not be null");        Objects.requireNonNull(callback, "callback must not be null");        final StanzaListener packetListener = new StanzaListener() {            @Override            public void processPacket(Stanza packet) throws NotConnectedException {                try {                    XMPPErrorException.ifHasErrorThenThrow(packet);                    callback.processPacket(packet);                }                catch (XMPPErrorException e) {                    if (exceptionCallback != null) {                        exceptionCallback.processException(e);                    }                }                finally {                    removeAsyncStanzaListener(this);                }            }        };        removeCallbacksService.schedule(new Runnable() {            @Override            public void run() {                boolean removed = removeAsyncStanzaListener(packetListener);                // If the packetListener got removed, then it was never run and                // we never received a response, inform the exception callback                if (removed && exceptionCallback != null) {                    exceptionCallback.processException(NoResponseException.newWith(AbstractXMPPConnection.this, replyFilter));                }            }        }, timeout, TimeUnit.MILLISECONDS);        addAsyncStanzaListener(packetListener, replyFilter);        sendStanza(stanza);    }    @Override    public void sendIqWithResponseCallback(IQ iqRequest, StanzaListener callback)                    throws NotConnectedException {        sendIqWithResponseCallback(iqRequest, callback, null);    }    @Override    public void sendIqWithResponseCallback(IQ iqRequest, StanzaListener callback,                    ExceptionCallback exceptionCallback) throws NotConnectedException {        sendIqWithResponseCallback(iqRequest, callback, exceptionCallback, getPacketReplyTimeout());    }    @Override    public void sendIqWithResponseCallback(IQ iqRequest, final StanzaListener callback,                    final ExceptionCallback exceptionCallback, long timeout)                    throws NotConnectedException {        StanzaFilter replyFilter = new IQReplyFilter(iqRequest, this);        sendStanzaWithResponseCallback(iqRequest, replyFilter, callback, exceptionCallback, timeout);    }    @Override    public void addOneTimeSyncCallback(final StanzaListener callback, final StanzaFilter packetFilter) {        final StanzaListener packetListener = new StanzaListener() {            @Override            public void processPacket(Stanza packet) throws NotConnectedException {                try {                    callback.processPacket(packet);                } finally {                    removeSyncStanzaListener(this);                }            }        };        addSyncStanzaListener(packetListener, packetFilter);        removeCallbacksService.schedule(new Runnable() {            @Override            public void run() {                removeSyncStanzaListener(packetListener);            }        }, getPacketReplyTimeout(), TimeUnit.MILLISECONDS);    }    @Override    public IQRequestHandler registerIQRequestHandler(final IQRequestHandler iqRequestHandler) {        final String key = XmppStringUtils.generateKey(iqRequestHandler.getElement(), iqRequestHandler.getNamespace());        switch (iqRequestHandler.getType()) {        case set:            synchronized (setIqRequestHandler) {                return setIqRequestHandler.put(key, iqRequestHandler);            }        case get:            synchronized (getIqRequestHandler) {                return getIqRequestHandler.put(key, iqRequestHandler);            }        default:            throw new IllegalArgumentException("Only IQ type of 'get' and 'set' allowed");        }    }    @Override    public final IQRequestHandler unregisterIQRequestHandler(IQRequestHandler iqRequestHandler) {        return unregisterIQRequestHandler(iqRequestHandler.getElement(), iqRequestHandler.getNamespace(),                        iqRequestHandler.getType());    }    @Override    public IQRequestHandler unregisterIQRequestHandler(String element, String namespace, IQ.Type type) {        final String key = XmppStringUtils.generateKey(element, namespace);        switch (type) {        case set:            synchronized (setIqRequestHandler) {                return setIqRequestHandler.remove(key);            }        case get:            synchronized (getIqRequestHandler) {                return getIqRequestHandler.remove(key);            }        default:            throw new IllegalArgumentException("Only IQ type of 'get' and 'set' allowed");        }    }    private long lastStanzaReceived;    public long getLastStanzaReceived() {        return lastStanzaReceived;    }    /**     * Install a parsing exception callback, which will be invoked once an exception is encountered while parsing a     * stanza     *      * @param callback the callback to install     */    public void setParsingExceptionCallback(ParsingExceptionCallback callback) {        parsingExceptionCallback = callback;    }    /**     * Get the current active parsing exception callback.     *       * @return the active exception callback or null if there is none     */    public ParsingExceptionCallback getParsingExceptionCallback() {        return parsingExceptionCallback;    }    protected final void asyncGo(Runnable runnable) {        cachedExecutorService.execute(runnable);    }    protected final ScheduledFuture<?> schedule(Runnable runnable, long delay, TimeUnit unit) {        return removeCallbacksService.schedule(runnable, delay, unit);    }}