Details
-
Bug
-
Status: Resolved
-
Minor
-
Resolution: Fixed
-
2.1.0
-
None
-
None
Description
Run following command in artemis-server root directory
[treblereel@dhcp-10-40-4-236 activemq-artemis]$ find -name "*.java" | grep -i -E -v "test|example|junit" | xargs grep -i -E "LOG(GER)*\.error\(|LOG(GER)*\.warn\(|LOG(GER)*\.info\(" ./artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/protocol/AbstractProtocolManager.java: ActiveMQServerLogger.LOGGER.error(e); ./artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/protocol/EmbedMessageUtil.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/security/ActiveMQJAASSecurityManager.java: logger.info("Can't find roles for the subject", e); ./artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/security/ActiveMQJAASSecurityManager.java: logger.info("Can't add role principal", e); ./artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/security/jaas/LDAPLoginModule.java: ActiveMQServerLogger.LOGGER.error(e.toString()); ./artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/security/jaas/LDAPLoginModule.java: ActiveMQServerLogger.LOGGER.error(e.toString()); ./artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/security/jaas/ReloadableProperties.java: ActiveMQServerLogger.LOGGER.error("Failed to load: " + key + ", reason:" + e.getLocalizedMessage()); ./artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/security/jaas/ReloadableProperties.java: // ActiveMQServerLogger.LOGGER.info("jasypt is not on the classpath: password decryption disabled."); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/paging/impl/PagingManagerImpl.java: logger.info("size = " + globalSizeBytes + " bytes, messages = " + numberOfMessages); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/paging/cursor/impl/PageCursorProviderImpl.java: ActiveMQServerLogger.LOGGER.warn("Error while cleaning paging on queue " + sub.getQueue().getName(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/paging/cursor/impl/PageCursorProviderImpl.java: ActiveMQServerLogger.LOGGER.warn("Error while cleaning page, during the commit", e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/paging/cursor/impl/PageSubscriptionImpl.java: ActiveMQServerLogger.LOGGER.warn("Error while deleting page-complete-record", e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/paging/cursor/impl/PageSubscriptionImpl.java: ActiveMQServerLogger.LOGGER.warn("Error while deleting page-complete-record", e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/paging/cursor/PagedReferenceImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/paging/cursor/PagedReferenceImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/protocol/core/ServerSessionPacketHandler.java: ActiveMQServerLogger.LOGGER.warn("Sending unexpected exception to the client", t); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationEndpoint.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationEndpoint.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationManager.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationManager.java: logger.warn("Missing replication token on queue"); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/registry/JndiBindingRegistry.java: //JMSServerManagerImpl.log.warn("Binding for " + jndiName + " already exists"); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/transaction/impl/TransactionImpl.java: ActiveMQServerLogger.LOGGER.warn(e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/remoting/impl/netty/NettyAcceptor.java: logger.warn("failed to send notification", e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/remoting/impl/invm/InVMAcceptor.java: logger.warn("failed to send notification", e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/remoting/server/impl/RemotingServiceImpl.java: logger.warn("Error executing afterCreateConnection plugin method: {}", t.getMessage(), t); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/remoting/server/impl/RemotingServiceImpl.java: logger.warn("Error executing afterDestroyConnection plugin method: {}", t.getMessage(), t); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/remoting/server/impl/RemotingServiceImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/postoffice/impl/PostOfficeImpl.java: logger.warn(throwable.getMessage(), throwable); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/JournalStorageManager.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/LargeServerMessageImpl.java: ActiveMQServerLogger.LOGGER.error(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/LargeServerMessageImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/LargeServerMessageInSync.java: logger.warn("Error while sincing data on largeMessageInSync::" + mainLM); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/AbstractJournalStorageManager.java: logger.info("There is no queue with ID " + statusEncoding.queueID + ", deleting record " + statusEncoding.getId()); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/AbstractJournalStorageManager.java: logger.warn("Invalid record type " + rec, new Exception("invalid record type " + rec)); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/AbstractJournalStorageManager.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/management/impl/view/ActiveMQAbstractView.java: //LOG.info("Exception sorting destinations", e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/config/impl/ConfigurationImpl.java: logger.info("Usage of wildcardRoutingEnabled configuration property is deprecated, please use wildCardConfiguration.enabled instead"); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/config/impl/ConfigurationImpl.java: ActiveMQServerLogger.LOGGER.warn("bridgeNoConnector(connectorName)"); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionImpl.java: ActiveMQServerLogger.LOGGER.warn(e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/Redistributor.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/Redistributor.java: ActiveMQServerLogger.LOGGER.warn(e2.getMessage(), e2); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BridgeImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BridgeImpl.java: // log.warn(name + "::Connection failed before reconnect ", exception); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ha/ColocatedHAManager.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterManager.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterManager.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterManager.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/BackupManager.java: ActiveMQServerLogger.LOGGER.error("Error announcing backup: backupServerLocator is null. " + this); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/group/impl/LocalGroupingHandler.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/SharedStoreBackupActivation.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: ActiveMQServerLogger.LOGGER.info(operationsExecuted.toString()); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: logger.warn("Internal error on plugin " + pluginRun, e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ColocatedActivation.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ColocatedActivation.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/LegacyLDAPSecuritySettingPlugin.java: logger.warn("Failed to process an event", e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/LegacyLDAPSecuritySettingPlugin.java: logger.warn("Failed to process an event", e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/LegacyLDAPSecuritySettingPlugin.java: ActiveMQServerLogger.LOGGER.error("Caught unexpected exception.", namingExceptionEvent.getException()); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/TransientQueueManagerImpl.java: ActiveMQServerLogger.LOGGER.warn("Error on deleting queue " + queueName + ", " + e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ServerSessionImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ServerSessionImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ServerSessionImpl.java: ActiveMQServerLogger.LOGGER.warn(e2.getMessage(), e2); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ServerSessionImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ServerSessionImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ServerSessionImpl.java: ActiveMQServerLogger.LOGGER.info("ignoring prepare on xid as already called :" + xid); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ServerSessionImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/FileLockNodeManager.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ServerConsumerImpl.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ScaleDownHandler.java: ActiveMQServerLogger.LOGGER.info("Scaled down " + num + " messages total."); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/InVMNodeManager.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/RefsOperation.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/RefsOperation.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/management/impl/ManagementServiceImpl.java: logger.warn("Failed to unregister acceptors", e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/files/FileStoreMonitor.java: logger.warn(e.getMessage(), e); ./artemis-server/src/main/java/org/apache/activemq/artemis/core/server/reload/ReloadManagerImpl.java: logger.warn("File " + file + " does not exist"); ./artemis-core-client/src/main/java/org/apache/activemq/artemis/core/remoting/impl/netty/NettyConnection.java: logger.warn("Trying to allocate " + size + " bytes, System is throwing OutOfMemoryError on NettyConnection " + this + ", there are currently " + "pendingWrites: [NETTY] -> " + totalPendingWriteBytes + "[EVENT LOOP] -> " + pendingWritesOnEventLoopView.get() + " causes: " + oom.getMessage(), oom); ./artemis-core-client/src/main/java/org/apache/activemq/artemis/core/remoting/impl/netty/NettyConnection.java: logger.warn("FAILURE! The code is using blockUntilWritable inside a Netty worker, which would block. " + ./artemis-commons/src/main/java/org/apache/activemq/artemis/utils/ByteUtil.java: logger.warn(e.getMessage(), e); ./artemis-commons/src/main/java/org/apache/activemq/artemis/utils/critical/CriticalAnalyzerImpl.java: logger.warn(e.getMessage(), e); ./artemis-commons/src/main/java/org/apache/activemq/artemis/utils/critical/CriticalAnalyzerImpl.java: logger.warn(e.getMessage(), e); ./artemis-commons/src/main/java/org/apache/activemq/artemis/utils/actors/OrderedExecutor.java: logger.warn(t.getMessage(), t); ./artemis-native/src/main/java/org/apache/activemq/artemis/jlibaio/LibaioContext.java: NativeLogger.LOGGER.error(e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireProtocolManager.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn("Errors occurred during the buffering operation ", e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e2); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.error("error sending", t); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn("Couldn't close connection because invalid clientID", e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: logger.warn("Failed to fire advisory on " + topic, e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn("Error during method invocation", e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: // LOG.warn("Failed to remove producer: {}", producerId, e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn("Error during method invocation", e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn("Error during method invocation", e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java: ActiveMQServerLogger.LOGGER.warn("Error during method invocation", e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQSession.java: ActiveMQServerLogger.LOGGER.error("error init session", e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQSession.java: logger.warn(e.getMessage(), e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQSession.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQSession.java: ActiveMQServerLogger.LOGGER.warn(e.getMessage(), e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQConsumer.java: ActiveMQServerLogger.LOGGER.warn("Error during message dispatch", e); ./artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQConsumer.java: ActiveMQServerLogger.LOGGER.warn("Error during message dispatch", t); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/client/ProtonClientConnectionManager.java: log.info("Connection " + amqpConnection.getRemoteAddress() + " created"); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/client/ProtonClientConnectionManager.java: log.info("Connection " + connection.getRemoteAddress() + " destroyed"); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/client/ProtonClientConnectionManager.java: log.info("Connection " + connection.getRemoteAddress() + " exception: " + me.getMessage()); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/client/ProtonClientConnectionManager.java: log.info("Connection " + connection.getRemoteAddress() + " ready"); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/broker/AMQPSessionCallback.java: logger.error("Error closing link for " + consumer.getQueue().getAddress()); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/broker/AMQPConnectionCallback.java: logger.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/broker/AMQPConnectionCallback.java: logger.warn("Couldn't find txid = " + txid); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/sasl/GSSAPIServerSASL.java: log.info("Error on sasl input: " + outOfHere.toString(), outOfHere); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/AMQPSessionContext.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/AMQPSessionContext.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/AMQPSessionContext.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/AMQPConnectionContext.java: log.error("Error init connection", e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/AMQPConnectionContext.java: log.warn("Handler is null, can't delivery " + delivery, new Exception("tracing location")); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/transaction/ProtonTransactionHandler.java: log.warn(amqpE.getMessage(), amqpE); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/transaction/ProtonTransactionHandler.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/ProtonServerSenderContext.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/ProtonServerSenderContext.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/ProtonServerSenderContext.java: log.warn(e.toString(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/handler/ProtonHandler.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/handler/ProtonHandler.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/handler/ProtonHandler.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/proton/ProtonServerReceiverContext.java: log.warn(e.getMessage(), e); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTPublishManager.java: logger.warn(t.getMessage(), t); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTPublishManager.java: log.warn("MQTT Client(" + session.getSessionState().getClientId() + ") attempted to Ack already Ack'd message"); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTPublishManager.java: log.error("Pub Sync Failed"); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTPublishManager.java: log.warn("MQTT Client(" + session.getSessionState().getClientId() + ") attempted to Ack already Ack'd message"); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTPublishManager.java: log.warn("Unable to send message: " + message.getMessageID() + " Cause: " + e.getMessage(), e); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSessionCallback.java: log.warn("Unable to send message: " + message.getMessageID() + " Cause: " + e.getMessage(), e); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSessionCallback.java: log.warn("Sending LARGE MESSAGE"); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSessionCallback.java: log.error(e.getMessage()); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTConnectionManager.java: log.error("Error disconnecting client: " + e.getMessage()); ./artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTProtocolManager.java: log.error(e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/io/aio/AIOSequentialFile.java: ActiveMQJournalLogger.LOGGER.warn(threadInfo.toString()); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/io/aio/AIOSequentialFile.java: ActiveMQJournalLogger.LOGGER.warn("waiting pending callbacks on " + fileName + " from " + (waitCount * 10) + " seconds!"); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/io/aio/AIOSequentialFile.java: ActiveMQJournalLogger.LOGGER.warn("interrupted while waiting pending callbacks on " + fileName, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/io/aio/AIOSequentialFile.java: ActiveMQJournalLogger.LOGGER.warn(e.getMessage(), e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/io/aio/AIOSequentialFileFactory.java: logger.warn(e.getMessage(), e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/io/aio/AIOSequentialFileFactory.java: ActiveMQJournalLogger.LOGGER.warn(e.getMessage(), e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/io/buffer/TimedBuffer.java: ActiveMQJournalLogger.LOGGER.warn(e.getMessage() + ", disabling sleep on TimedBuffer, using spin now", e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalFilesRepository.java: ActiveMQJournalLogger.LOGGER.info(debugFiles()); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalFilesRepository.java: ActiveMQJournalLogger.LOGGER.info(debugFiles()); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalFilesRepository.java: ActiveMQJournalLogger.LOGGER.info(debugFiles()); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalFilesRepository.java: ActiveMQJournalLogger.LOGGER.info(debugFiles()); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalCompactor.java: logger.warn(e.getMessage(), e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalFileImpl.java: logger.warn("Error during method invocation", e.getMessage(), e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendAddRecord::" + e, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendUpdateRecord:" + e, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendDeleteRecord:" + e, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendAddRecordTransactional:" + e, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendUpdateRecordTransactional:" + e.getMessage(), e ); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendDeleteRecordTransactional:" + e, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendPrepareRecord:" + e, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendCommitRecord:" + e, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.error("appendRollbackRecord:" + e, e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: ActiveMQJournalLogger.LOGGER.warn(e.getMessage(), e); ./artemis-journal/src/main/java/org/apache/activemq/artemis/core/journal/impl/JournalImpl.java: logger.warn("Error during compact", e.getMessage(), e); ./artemis-hawtio/activemq-branding/src/main/java/org/apache/activemq/hawtio/branding/PluginContextListener.java: LOG.info("Initialized {} plugin", plugin.getName()); ./artemis-hawtio/activemq-branding/src/main/java/org/apache/activemq/hawtio/branding/PluginContextListener.java: LOG.info("Destroyed {} plugin", plugin.getName()); ./artemis-hawtio/artemis-plugin/src/main/java/org/apache/activemq/hawtio/plugin/PluginContextListener.java: LOG.info("Initialized {} plugin", plugin.getName()); ./artemis-hawtio/artemis-plugin/src/main/java/org/apache/activemq/hawtio/plugin/PluginContextListener.java: LOG.info("Destroyed {} plugin", plugin.getName()); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.error(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), e)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.error(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), e)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.error(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), e)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: ActiveMQJournalLogger.LOGGER.error("Unable to connect to database using URL: " + jdbcConnectionUrl); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.warn(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), e)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: ActiveMQJournalLogger.LOGGER.warn("Unable to set a network timeout on the JDBC connection"); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.warn("Unable to set a network timeout on the JDBC connection", throwable); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.error(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), e, dropTableSql)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.error(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), rollbackEx, dropTableSql)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.warn(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), sqlWarning)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.warn(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), statementSqlWarning, sql)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.error(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), e, sqlStatements)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java: logger.error(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), rollbackEx, sqlStatements)); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/file/JDBCSequentialFileFactory.java: ActiveMQJournalLogger.LOGGER.error("Error stopping file factory, unable to close db connection"); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/file/JDBCSequentialFileFactory.java: logger.error("Error destroying file factory", e); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/file/JDBCSequentialFile.java: logger.warn(e.getMessage(), e); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/journal/JDBCJournalImpl.java: logger.warn(e.getMessage(), e); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/journal/JDBCJournalImpl.java: logger.warn(rollback); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/journal/JDBCJournalImpl.java: logger.warn(rollback); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/journal/JDBCJournalImpl.java: logger.warn(e.getMessage(), e); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/journal/JDBCJournalImpl.java: logger.error("Replication is not supported with JDBC Store", new Exception("trace")); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/journal/JDBCJournalImpl.java: logger.error("Replication is not supported with JDBC Store", new Exception("trace")); ./artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/journal/JDBCJournalRecord.java: ActiveMQJournalLogger.LOGGER.error("Error occurred whilst reading Journal Record", e);
Attachments
Issue Links
- is a clone of
-
ARTEMIS-1226 Log messages without prefixed id code in artemis-jms-client
- Closed
- links to