当前位置: 首页>>代码示例>>Java>>正文


Java MqttException类代码示例

本文整理汇总了Java中org.eclipse.paho.client.mqttv3.MqttException的典型用法代码示例。如果您正苦于以下问题:Java MqttException类的具体用法?Java MqttException怎么用?Java MqttException使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。


MqttException类属于org.eclipse.paho.client.mqttv3包,在下文中一共展示了MqttException类的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Java代码示例。

示例1: connect

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
public void connect() {
    try {
        client = new MqttAsyncClient((configuration.isSsl() ? "ssl" : "tcp") + "://" + configuration.getHost() + ":" + configuration.getPort(),
                getClientId(), new MemoryPersistence());
        client.setCallback(this);
        clientOptions = new MqttConnectOptions();
        clientOptions.setCleanSession(true);
        if (configuration.isSsl() && !StringUtils.isEmpty(configuration.getTruststore())) {
            Properties sslProperties = new Properties();
            sslProperties.put(SSLSocketFactoryFactory.TRUSTSTORE, configuration.getTruststore());
            sslProperties.put(SSLSocketFactoryFactory.TRUSTSTOREPWD, configuration.getTruststorePassword());
            sslProperties.put(SSLSocketFactoryFactory.TRUSTSTORETYPE, "JKS");
            sslProperties.put(SSLSocketFactoryFactory.CLIENTAUTH, false);
            clientOptions.setSSLProperties(sslProperties);
        }
        configuration.getCredentials().configure(clientOptions);
        checkConnection();
        if (configuration.getAttributeUpdates() != null) {
            configuration.getAttributeUpdates().forEach(mapping ->
                    gateway.subscribe(new AttributesUpdateSubscription(mapping.getDeviceNameFilter(), this))
            );
        }
        if (configuration.getServerSideRpc() != null) {
            configuration.getServerSideRpc().forEach(mapping ->
                    gateway.subscribe(new RpcCommandSubscription(mapping.getDeviceNameFilter(), this))
            );
        }
    } catch (MqttException e) {
        log.error("[{}:{}] MQTT broker connection failed!", configuration.getHost(), configuration.getPort(), e);
        throw new RuntimeException("MQTT broker connection failed!", e);
    }
}
 
开发者ID:osswangxining,项目名称:iot-edge-greengrass,代码行数:33,代码来源:MqttBrokerMonitor.java

示例2: testWithDefaultStatusPublisher

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
@Test
public void testWithDefaultStatusPublisher() throws MqttException, InterruptedException
{
    StaticApplicationContext applicationContext = getStaticApplicationContext();
    PahoAsyncMqttClientService service = new PahoAsyncMqttClientService(
        BrokerHelper.getBrokerUri(), BrokerHelper.getClientId(),
        MqttClientConnectionType.PUBSUB, null);
    service.setApplicationEventPublisher(applicationContext);
    service.start();
    Assert.assertTrue(service.isConnected());
    Assert.assertTrue(service.isStarted());
    Thread.sleep(1100);
    Assert.assertEquals(0, messageDeliveredCount.get());
    Assert.assertEquals(0, messagePublishedCount.get());
    service.stop();
    service.close();
}
 
开发者ID:christophersmith,项目名称:summer-mqtt,代码行数:18,代码来源:ConnectionStatusTest.java

示例3: stopListening

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
@Override
public void stopListening() {
    try {
        if (orderExecutorService != null) {
            ProcessorHelper.shutdownProcessors(orderExecutorService, orderQueue, 5, TimeUnit.SECONDS);
        }
        if (mqttClient.isConnected()) {
            LOGGER.info("Stopping MQTT client.");
            String[] paths = comboBySource.keySet().toArray(new String[comboBySource.size()]);
            mqttClient.unsubscribe(paths);
            mqttClient.disconnect();
        } else {
            LOGGER.info("MQTT client already stopped.");
        }
    } catch (MqttException ex) {
        LOGGER.error("Problem while disconnecting!", ex);
    }
}
 
开发者ID:hylkevds,项目名称:SensorThingsProcessor,代码行数:19,代码来源:ProcessorBatchAggregate.java

示例4: initializeMqttClient

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
private void initializeMqttClient()
    throws MqttException, IOException, NoSuchAlgorithmException, InvalidKeySpecException {

    mqttClient = new MqttClient(cloudIotOptions.getBrokerUrl(),
        cloudIotOptions.getClientId(), new MemoryPersistence());

    MqttConnectOptions options = new MqttConnectOptions();
    // Note that the the Google Cloud IoT only supports MQTT 3.1.1, and Paho requires that we
    // explicitly set this. If you don't set MQTT version, the server will immediately close its
    // connection to your device.
    options.setMqttVersion(MqttConnectOptions.MQTT_VERSION_3_1_1);
    options.setUserName(CloudIotOptions.UNUSED_ACCOUNT_NAME);

    // generate the jwt password
    options.setPassword(mqttAuth.createJwt(cloudIotOptions.getProjectId()));

    mqttClient.connect(options);
    mReady.set(true);
}
 
开发者ID:androidthings,项目名称:sensorhub-cloud-iot,代码行数:20,代码来源:MQTTPublisher.java

示例5: unRealizeSubscriptions

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
private void unRealizeSubscriptions ( final Hive hive, final ObjectPool<MqttItemToTopic> pool ) throws InvalidSessionException, MqttException
{
    if ( this.poolListener != null )
    {
        pool.removeListener ( this.poolListener );
    }
    if ( this.session != null )
    {
        this.session.setListener ( (ItemChangeListener)null );
        hive.closeSession ( this.session );
    }
    if ( this.client != null )
    {
        this.client.setCallback ( null );
    }
}
 
开发者ID:eclipse,项目名称:neoscada,代码行数:17,代码来源:MqttExporter.java

示例6: unsubscribe

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
private void unsubscribe ( final Session session, final MqttItemToTopic itemToTopic ) throws InvalidSessionException, InvalidItemException, MqttException
{
    this.executor.submit ( new Callable<Void> () {
        @Override
        public Void call () throws Exception
        {
            logger.trace ( "unsubscribe () called with '{}'", itemToTopic );
            if ( itemToTopic.isReadable () )
            {
                MqttExporter.this.itemsToReadTopics.remove ( itemToTopic.getItemId () );
                MqttExporter.this.hive.unsubscribeItem ( session, itemToTopic.getItemId () );
            }
            if ( itemToTopic.isWritable () )
            {
                logger.trace ( "unsubscribe () called on topic '{}'", makeWriteTopicName ( itemToTopic ) );
                MqttExporter.this.itemsToWriteTopics.remove ( itemToTopic.getItemId () );
                MqttExporter.this.client.unsubscribe ( makeWriteTopicName ( itemToTopic ) );
            }
            return null;
        }
    } );
}
 
开发者ID:eclipse,项目名称:neoscada,代码行数:23,代码来源:MqttExporter.java

示例7: writeMessageToItem

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
/**
 * convert received mqtt message and write it to item
 *
 * @param hive
 * @param session
 * @param itemId
 * @param message
 * @throws InvalidSessionException
 * @throws PermissionDeniedException
 * @throws InvalidItemException
 * @throws MqttException
 */
private void writeMessageToItem ( final Hive hive, final Session session, final String itemId, final MqttMessage message ) throws InvalidSessionException, PermissionDeniedException, InvalidItemException, MqttException
{
    final DataItemValue div = messageToValue ( itemId, message );
    if ( div != null )
    {
        if ( div.getValue () != null )
        {
            hive.startWrite ( session, itemId, div.getValue (), null, null );
        }
        if ( div.getAttributes () != null && !div.getAttributes ().isEmpty () )
        {
            hive.startWriteAttributes ( session, itemId, div.getAttributes (), null, null );
        }
    }
}
 
开发者ID:eclipse,项目名称:neoscada,代码行数:28,代码来源:MqttExporter.java

示例8: messageToValue

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
/**
 * @param itemId
 * @param message
 *            from MQTT topic
 * @return converted value
 * @throws MqttException
 */
private DataItemValue messageToValue ( final String itemId, final MqttMessage message ) throws MqttException
{
    final DataItemValue div;
    try
    {
        div = gson.fromJson ( new String ( message.getPayload (), "UTF-8" ), DataItemValue.class );
        if ( message.isRetained () || message.isDuplicate () )
        {
            logger.info ( "message is retained/duplicate, will not write" );
            return null;
        }
        return div;
    }
    catch ( JsonSyntaxException | UnsupportedEncodingException e1 )
    {
        logger.warn ( "could not parse message {}", message );
        return null;
    }
}
 
开发者ID:eclipse,项目名称:neoscada,代码行数:27,代码来源:MqttExporter.java

示例9: MqttClientKetiSub

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
public MqttClientKetiSub(String serverUrl) {
	
	this.mqttServerUrl = serverUrl;
	
	System.out.println("[KETI MQTT Client] Client Initialize");
	
	try {
		mqc = new MqttClient(mqttServerUrl, mqttClientId, persistence);
		
		while(!mqc.isConnected()){
			mqc.connect();
			System.out.println("[KETI MQTT Client] Connection try");
		}
		
		System.out.println("[KETI MQTT Client] Connected to Server - " + mqttServerUrl);
	} catch (MqttException e) {
		e.printStackTrace();
	}
}
 
开发者ID:IoTKETI,项目名称:nCube-Thyme-Java,代码行数:20,代码来源:MqttClientKetiSub.java

示例10: MqttClientKetiPub

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
public MqttClientKetiPub(String serverUrl) {
	
	this.mqttServerUrl = serverUrl;
	
	System.out.println("[KETI MQTT Client] Client Initialize");
	
	try {
		mqc = new MqttClient(mqttServerUrl, mqttClientId, persistence);
		
		while(!mqc.isConnected()){
			mqc.connect();
			System.out.println("[KETI MQTT Client] Connection try");
		}
		
		System.out.println("[KETI MQTT Client] Connected to Server - " + mqttServerUrl);
	} catch (MqttException e) {
		e.printStackTrace();
	}
}
 
开发者ID:IoTKETI,项目名称:nCube-Thyme-Java,代码行数:20,代码来源:MqttClientKetiPub.java

示例11: onPublish

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
private void onPublish(final String requestId, final String topic, final byte[] payload) {
    if (!clientIsConnected()) {
        broadcastException(BROADCAST_EXCEPTION, requestId,
                           new Exception("Can't publish to topic: " + topic + ", client not connected!"));
        return;
    }

    try {
        MQTTServiceLogger.debug("onPublish", "Publishing to topic: " + topic + ", payload with size " + payload.length);
        MqttMessage message = new MqttMessage(payload);
        message.setQos(0);
        mClient.publish(topic, message);
        MQTTServiceLogger.debug("onPublish", "Successfully published to topic: " + topic + ", payload: " + payload);

        broadcast(BROADCAST_PUBLISH_SUCCESS, requestId,
                PARAM_TOPIC, topic
        );

    } catch (Exception exc) {
        broadcastException(BROADCAST_EXCEPTION, requestId, new MqttException(exc));
    }
}
 
开发者ID:iGenius-Srl,项目名称:android-mqtt-service,代码行数:23,代码来源:MQTTService.java

示例12: connectClient

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
private void connectClient() {
  try {
    client = new MqttClient(broker, clientId);
    client.setCallback(this);
    MqttConnectOptions connOpts = new MqttConnectOptions();
    connOpts.setUserName(user);
    connOpts.setPassword(password.toCharArray());
    connOpts.setCleanSession(true);
    connOpts.setKeepAliveInterval(OUTGOING_MQTT_KEEP_ALIVE);
    logger.debug("Connecting to broker:  " + broker);
    client.connect(connOpts);
    logger.debug("Connected");
  } catch (MqttException e) {
    logger.error("Failed to connect to MQTT client ( " + broker + "/" + clientId
        + ") for outbound messages");
    logger.error(e.getLocalizedMessage());
    e.printStackTrace();
  }
}
 
开发者ID:edgexfoundry,项目名称:device-mqtt,代码行数:20,代码来源:OutgoingSender.java

示例13: startListening

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
private void startListening() {
  logger.debug("Starting listening for response traffic");
  try {
    String url =
        cmdrespMqttBrokerProtocol + "://" + cmdrespMqttBroker + ":" + cmdrespMqttBrokerPort;
    client = new MqttClient(url, cmdrespMqttClientId);
    MqttConnectOptions connOpts = new MqttConnectOptions();
    connOpts.setUserName(cmdrespMqttUser);
    connOpts.setPassword(cmdrespMqttPassword.toCharArray());
    connOpts.setCleanSession(true);
    connOpts.setKeepAliveInterval(cmdrespMqttKeepAlive);
    logger.debug("Connecting to response message broker:  " + cmdrespMqttBroker);
    client.connect(connOpts);
    logger.debug("Connected to response message broker");
    client.setCallback(this);
    client.subscribe(cmdrespMqttTopic, cmdrespMqttQos);
  } catch (MqttException e) {
    logger.error("Unable to connect to response message queue.  "
        + "Unable to respond to command requests.");
    e.printStackTrace();
    client = null;
  }
}
 
开发者ID:edgexfoundry,项目名称:device-mqtt,代码行数:24,代码来源:CommandResponseListener.java

示例14: startListening

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
private void startListening() {
  logger.debug("Starting listening for incoming traffic");
  try {
    String url =
        incomingMqttBrokerProtocol + "://" + incomingMqttBroker + ":" + incomingMqttBrokerPort;
    client = new MqttClient(url, incomingMqttClientId);
    MqttConnectOptions connOpts = new MqttConnectOptions();
    connOpts.setUserName(incomingMqttUser);
    connOpts.setPassword(incomingMqttPassword.toCharArray());
    connOpts.setCleanSession(true);
    connOpts.setKeepAliveInterval(incomingMqttKeepAlive);
    logger.debug("Connecting to incoming message broker:  " + incomingMqttBroker);
    client.connect(connOpts);
    logger.debug("Connected to incoming message broker");
    client.setCallback(this);
    client.subscribe(incomingMqttTopic, incomingMqttQos);
  } catch (MqttException e) {
    logger.error("Unable to connect to incoming message queue.");
    e.printStackTrace();
    client = null;
  }
}
 
开发者ID:edgexfoundry,项目名称:device-mqtt,代码行数:23,代码来源:IncomingListener.java

示例15: close

import org.eclipse.paho.client.mqttv3.MqttException; //导入依赖的package包/类
@Override
public void close()
{
    reentrantLock.lock();
    try
    {
        stop();
        mqttClient.close();
        LOG.info(
            String.format("Client ID %s is closed and cannot be restarted.", getClientId()));
    }
    catch (MqttException ex)
    {
        LOG.error(
            String.format("Client ID %s encountered an error while closing.", getClientId()),
            ex);
    }
    finally
    {
        reentrantLock.unlock();
    }
}
 
开发者ID:christophersmith,项目名称:summer-mqtt,代码行数:23,代码来源:PahoAsyncMqttClientService.java


注:本文中的org.eclipse.paho.client.mqttv3.MqttException类示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。