You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@qpid.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2014/07/05 00:19:47 UTC

Build failed in Jenkins: Qpid-Java-Artefact-Release #1128

See <https://builds.apache.org/job/Qpid-Java-Artefact-Release/1128/changes>

Changes:

[robbie] QPID-5610: update readme to detail usage of the copy-broker profile

[robbie] QPID-5610: add a profile to optionally extract the broker release artifact and copy the QMF2 broker plugin into the lib dir

[kwall] QPID-5873: Exclude new ACL system tests from Json profile; fix BDBHARemoteReplicationNodeTest unit test wrt monitor attribute

[macbean] QPID-5876: [Java Client] Highest delivery tag variable not reset after failover and causes rejections to be sent

Work by Keith Wall <kw...@apache.org> and me.

[kwall] QPID-5873: [Java Broker] Allow ACL rules to be applied to VirtualHostNode objects

* ACL rules using the new operation VIRTUALHOSTNODE apply to VHN model objects.
* ACL rules using the operation VIRTUALHOST apply to VH model objects for CREATE, UPDATE and DELETE.  This
  is a change from previous version where BROKER operation permission was required.
* For HA, VIRTUALHOSTNODE permission is required to perform updates on RemoteReplicationNodes.

[macbean] QPID-5877: [Java Broker] Potential for rejected messages to be resent out of order

Work completed by Keith Wall <kw...@apache.org> and me.

[orudyy] QPID-5875: Fix intruder protection system test

[orudyy] QPID-5875: Exclude test VirtualHostRestTest.testPutCreateVirtualHostUsingProfileNodeType from json profiles

[orudyy] QPID-5867: Add intruder protection functionality for a cluster of BDB HA virtual host nodes

[astitcher] QPID-5874: Treat all empty selectors sensibly

[astitcher] QPID-5806: Allow quoted syntax for non standard selector identifiers
- This matches the Java broker syntax for selectors

[chug] QPID-5869: Check that agent is not null before firing event.
Propagate Rajith's logic to the rest of the cases in Acl code.

[pmoravec] [QPID-5866]: [C++ client] AMQP 1.0 closing session without closing receiver first marks further messages as redelivered (previous commit not complete)

[pmoravec] [QPID-5866]: [C++ client] AMQP 1.0 closing session without closing receiver first marks further messages as redelivered

[astitcher] QPID-5871: Remove unused generated code and dependent code

[rajith] QPID-5869 Added a check to see if agent is null before firing the event.
There are other places in the code where this check is missing. Chuck will take care of them.

[astitcher] QPID-3921: Removed unused header includes

[astitcher] QPID-3921: Deleted unnecessary header file includes

[astitcher] QPID-5859: Fix to allow listening to some interfaces to fail
- but still listen to the succeeding ones

[astitcher] QPID-3921: Refactored Broker::Options into its own independent class
- Now called BrokerOptions
- Added extra getters to Broker so that nothing else needs to know
  about BrokerOptions
- Significantly reduces header coupling as lots of files include
  Broker.h, but now don't need Options.h

[astitcher] QPID-5865: Be more robust in face of system clock being changed:
- Separate Wall clock time uses from other time
  * (assumed that any time with respect to the epoch is wallclock)
- For Posix use CLOCK_MONOTONIC for all non wall clock purposes
  so that changing system time doesn't affect internal timekeeping
- For Windows kept the same time keeping scheme.

[pmoravec] [QPID-5864]: [Python client] Provide better error description when SASL required but no credentials provided

[pmoravec] [QPID-5863]: qpid-config does not throws correct exception when binding nonexisting exchange; fix from Zdenek Kraus

[kwall] QPID-5820: [Java QMF2 Plugin] changes to plugin owing to the Java Broker model updates made during 0.29

* Used model getters rather than named attributes wherever possible

Work done by Andrew MacBean <ma...@apache.org> and me.

[tross] NO-JIRA - Fixed typo in a comment.

[kwall] QPID-5820: [Java QMF2 Plugin] changes to plugin owing to the Java Broker model updates made during 0.29

* VHNs (virtualhostnodes) may exist within a VH (virtualhost)
* Use Port#availableProtocols rather than Port#protocols when trying to find the AMQP port
* Like the CPP Broker, Binding#arguments will be null if the binding was created with none.

Note that the QMF plugin still does not support virtualhosts created at runtime.  They'll be ignored until
the next restart.

Work done by Andrew MacBean <ma...@apache.org> and me.

[orudyy] QPID-5853: Fix quote character location in broker command

[gsim] QPID-5860: release sender lock before invoking on session

[gsim] QPID-5858: prevent leakage of old exception types

[astitcher] QPID-5859: Make qpidd listen to all protocol addresses when it starts up.

[orudyy] QPID-5853: Fix quote character location in broker command for Windows

[orudyy] QPID-5857: Strengthen test ConsumerLoggingTest.testSubscriptionCreateQueueBrowser by collecting operational logs after browser subscription is closed

[aconway] NO-JIRA: Error handling in swig_python_typemaps: don't core dump if qpid.datatypes is not found.

[aconway] NO-JIRA: Updated java/README.txt with instructions to run examples.

[robbie] QPID-5048: add pom to build the AMQP 0-x JMS client examples

[pmoravec] [QPID-5852]: [Python client] connection.opened() returns True after unsuccessful connection

[orudyy] QPID-5853: Use quotes in broker command line provided by maven profile in order to allow command line arguments with spaces

[macbean] NO-JIRA: [Java Tests] BDB tests - prevent sporadic test failure from quorum override test.

Work by Keith Wall <kw...@apache.org> and myself.

[macbean] QPID-5821: [Java Broker] Make JDBC username and password separate attributes within the model

Work done by Keith Wall <kw...@apache.org> and me.

[macbean] QPID-5821: Remove unused settings interface incorrectly committed

[macbean] QPID-5821: [Java Broker] Refactor MessageStore and DurableConfigurationStore interfaces to remove message store settings map.

VirtualHost model objects now have attributes.

Work done by Keith Wall <kw...@apache.org> and me.

[pmoravec] QPID-5836: [Python client] Report error when encountering unrecognized connection option

[pmoravec] [no JIRA]: brokertest to set connection option 'protocol' only for SWIG client on AMQP1.0

[orudyy] QPID-5851: [Java Broker] Introduce new test profiles for JSON configuration store and persistent message store

[pmoravec] [no JIRA]: mark flow-to-disk stats as deprecated

[aconway] QPID-5843: Producing to many queues locks I/O threads for new connections

This patch changes where the duration is calculated in
sys/posix/AsyncIO.cpp->readable(). This will prevent the loop from executing
past the threadMaxIoTimeNs. Doing this decreased the connection delay observed
by 19%.

[aconway] NO-JIRA: Fix tools/setup.py, was not respecting install prefix.

- Was installing into absolute /usr directories, changed to install relative to prefix.
- Was installing to non-standard "/usr/shared" directory, changed to Unix standard "<prefix>/share"

[aconway] NO-JIRA: Added README.txt to java directory.

[gsim] QPID-5849: set mechanism on management connection even if auth=no

[kwall] NO-JIRA: [Java Broker Tests] Add test checking the ability to delete (i.e. close) a messaging connection from the
management layer.

[gsim] QPID-5828: more consistent behaviour os send() when disconnected

[gsim] QPID-5848: update reference doc for connection options

[orudyy] QPID-5846: Fix NPE in org.apache.qpid.server.virtualhost.berkeleydb.BDBHAVirtualHostImpl.isCoalescingSync()

[gsim] QPID-5845: topic policy's auto delete delay should not be overridden by link specific timeout

[gsim] QPID-5841: allow SSL hostname verification failure to be ignored (with NSS)

[chug] PQID-5840: .NET Binding example.server confuses argument indexing
Don't require an unused argument just to keep connectionOptions as arg[2]

[kwall] NO-JIRA: [Java 0-8..0-9-1 Client Book] Add AMQAuthenticationException/AMQSecurityException to exception catalogue

[robbie] QPID-5792: add null check to avoid NPE during Destination decoding

Applied patch from Dejan Bosanac

[pmoravec] QPID-5839: [C++ broker] Broker does not set lifetime-policy in AMQP1.0 attach performative

[kwall] QPID-5834: [Java Broker] Move validation that prevents to deletion of default virtualhost to validate, in order that it can veto the proposed state change

* Added a unit test, improve other VH unit tests
* Removed MockVirtualHost

[gsim] QPID-5828: Drop expired incoming messages

[gsim] QPID-5828: Check and adjust ttl on resend attempt

[orudyy] QPID-5715: Set BDB message store durability only once on opening of virtual host. Restore original code of coalescing committer.

[macbean] NO-JIRA: added test exludes for transient profiles where the tests assume VH state after restart

[gsim] QPID-5828: Ensure that we don't try to check status of null completion handle

[pmoravec] QPID-5835: [C++ broker] Broker recovery forgets auto-delete flag on queues and exchanges

[kwall] QPID-5803: [Java Broker] Add a utilised flag to the VHN context after the blueprint has been used.

This prevents the virtualhost from being automatically recreated by the blueprint, should the user choose to the VH.
Strenghthen unit tests.

[kwall] QPID-5800: [Java Broker] Defect - prevent JDBC upgrader on throwing exception due to open transaction causing exception to log

[kwall] QPID-5819: Make JsonFileConfigStore#close idempotent, like other DCS implementations

[macbean] QPID-5825: Changes to address some review comments for initial commit

[kwall] QPID-5800: [Java Broker] Refactor BDB message store implementation to separate message and config store implementations.

* Message store implementations can now be used in isolation, which is useful when the user is using a JSON VirtualHostNode with
  a BDB virtual host.

[macbean] QPID-5831: Unexpected internal exception when closing JE Replicated environment

[macbean] QPID-5825: Broker tries to downgrade to the wrong amqp protocol version

[astitcher] QPID-5807: Fix inconsistent DLL linkage

[astitcher] NO-JIRA: Fix some MSVC warnings

[kwall] QPID-5822: [Java Broker] Replace low level BDB/JDBC attributes in fovour of context variables from the model

* BDB attributes environmentConfiguration/replicatedEnvironmentConfiguration removed.  User can now specify
  context variables with the configuration keys that are understood by JE itself.
* JDBC attributes bigIntType/bytesForBlob/varBinaryType/blobType are now context variables with names begining qpid.jdbcstore.

[astitcher] QPID-5829: This rearrangement is really it...

[kwall] QPID-5800: [Java Broker] Refactor Derby/JDBC message store implementations - Address review comments from Alex Rudyy

[kwall] QPID-5800: [Java Broker] Refactor Derby/JDBC message store implementations to separate message and config store implementations.

* Message store implementations can now be used in isolation, which is useful when the user is using a JSON VirtualHostNode with
  another persistent store implementation.

[astitcher] QPID-5829: One more CMake rearrangement and all will be good...

[chug] QPID-5829: Rearrange CMake - repair original commit that breaks the .NET binding
r1603064 fails to define some CMake version variables before using them for template processing.

[pmoravec] QPID-5830: [Python client] Unable to create bindings on already existing broker objects using addressing

[pmoravec] QPID-5817: [C++ broker] Improve ACL authorisation of QMF methods and queries

[astitcher] NO-JIRA: Make bindings install on windows

[kwall] QPID-5785: [Java Broker] Fix NPE when a topic exchange is closed after a message filter has been added to an existing binding.

This corrects a regression introduced by QPID-5709 that was causing a NPE to appear in the test log for QueueBindingTest.

[astitcher] QPID-5829: Properly fix the CMake conditional

[astitcher] QPID-5829: Oops - fix mistaken change to actually work on Windows

[astitcher] QPID-5829: Rearrange CMake files to centralise some flags
- This means they can be used in the bindings.
- It also means that individual modules do not have to specify
  to catch undefined symbols as this is the default beahviour now.

[pmoravec] QPID-5823: (reverting commit r1602820) Python client should create a node with name starting '\#'

[pmoravec] QPID-5823: Python client should create a node with name starting '\#'

[kwall] QPID-5802: [Java Broker] Refactor VH implementations to avoid duplicated message store/message store subject code.

This addresses review comments from Alex Rudyy.

[kwall] QPID-5801: [Java Broker] BDB HA - ensure that replication exceptions when reading the message id sequence cause the environment to restart

Addresses review comment from Alex Rudyy.

[kwall] NO-JIRA: [Java Broker Documentation] Fix typo in operational message codes in appendix

[kwall] NO-JIRA: [Java Broker Test] Derby tests profile should exclude BDB replication tests

[kwall] QPID-5800: [Java Broker] Refactor BDBConfigurationStore, move methods/fields associated with only BDBMessageStore to the inner class.

Addresses review comment from Alex Rudyy.

[gsim] QPID-5814: default to utf8 in Variant::parse()

[astitcher] QPID-3921: Don't leak use qpid/Options.h header unnecessarily.

[astitcher] NO-JIRA: We never want to accidentally convert a string to an Options object

[astitcher] NO-JIRA: Removed obsolete/unused store code

[astitcher] Revert "QPID-5812: python high level API client receiver.fetch(timeout=N) blocks forever in select() if broker is stopped (kill -STOP)"

This reverts commit r1602221 As it breaks the C++ tests:
- python_tests
- federation_sys_tests
- legacystore_python_tests

[pmoravec] QPID-5812: python high level API client receiver.fetch(timeout=N) blocks forever in select() if broker is stopped (kill -STOP)

[kwall] QPID-5721: Improve exception message used when String operand cannot be interpreted as JSON

* Also made AVC consistently return unmodifiable when converting from a JSON string

[astitcher] QPID-5807: Remove boost::program_options as a header file dependency of qpid/Options.h
- The intent here is to remove the necessity for things using qpid::Options to
  need to link boost::program_options directly.

[astitcher] QPID-3650: Avoid unaligned memory access

[astitcher] QPID-3650: Avoid unaligned memory access

[macbean] QPID-5811: logging to assist investigation of test failure

[kgiusti] QPID-5808: framer should consume only header bytes

[orudyy] QPID-5715: Move coalescing commiters into environment facades. Flush logs for not completed commit futures if commit task is stopped

[astitcher] QPID-5805: Disallow % and _ characters as escapes in selector LIKE expression

[astitcher] QPID-5804: Fix broken selector parsing of unary '+'

[kwall] QPID-5801: [Java Broker] BDB: Cache the sequence handler used for message sequence number

[kwall] QPID-5801: [Java Broker] BDB: Simply restore algorithm to efficiently calculate utilised disk space.

[orudyy] QPID-5715: Close committer on message store close

[orudyy] QPID-5715: Unregister children MBeans on Virtual Host Node stop

[kwall] QPID-5803: [Java Broker] Add ability for the virtualhostnode to create a virtualhost using a blueprint supplied by context variable

* This commit reenables the SplitStoreTest.
* The UI has not been refactored by this commit, so it will not be possible to create a non-HA virtualhost from the UI
  (the UI will create only a virtualhostnode).. REST API is okay.

[kwall] QPID-5800: [Java Broker] Remove the now redundant MessageStore/DurableConfigurationStore factories

[kwall] QPID-5802: [Java Broker] Introduce separate VirtualHost types

[kwall] QPID-5801: [Java Broker] Elimination of the BDB facade's initialisation tasks

[kwall] QPID-5802: [Java Broker] Temporarily remove the slow message store and quota message store
test implementations and the tests that rely on them.

[kwall] QPID-5800: [Java Broker] Add DurableConfigurationStore#onDelete method to allow an implementation to
delete the files/tables/databases underlying the store.

[kwall] QPID-5800: [Java Broker} Refactor MessageStore implementations extracting a MessageStoreProvider interface.

[orudyy] QPID-5715: Fix various issues with configuration upgrader to model 2 and store upgraders to version 8

[kwall] QPID-5721: [Java Broker] Improve test coverage for default attributes, and attributes whose values are computed from context variables.

Also fixed defect so that a context attributes are resolved first, so that other attribute values may be calculated from context variables
set on the same object.

[gsim] NO-JIRA: Fix incorrectly named transport option. Add description for protocol option.

[gsim] QPID-5788: delayed initiation of nss

[kwall] QPID-5798: [Java Broker Tests] Intermittent failure of FailoverBehaviourTest due to race condition within test

Work by Andrew MacBean <an...@gmail.com>

[gsim] QPID-5793: prevent leak due to concurrent bind and delete

[gsim] QPID-5793: prevent deadlock between timer and consume

[orudyy] QPID-5715: Use coalescing sync committer for message store transactions only when syncronization policy SYNC is set for local transactions in BDB HA virtual host

[kpvdr] QPID-5767: [linearstore] broker segfaults when recovering journal file with damaged header

[pmoravec] QPID-5797: [qpid-tools]: inability to call some QMF methods (queueMoveMessages / setLogLevel or so)

[chug] QPID-5783: Share immutable state EXTERN

[kwall] QPID-5795: [Java Broker] Prevent ConnectionAdapter leak when closing a messaging connection

The leak was due to the fact that nothing was telling the virtualhost to unregister the connection child (#unregisterChild)
when the connection was closed.

* Made ConnectionAdapter responsible for causing its own deletion (when the underlying connection is closed).  The call to #deleted() causes the child
 to be unregistered from its parent (preventing the leak)
* Removed the now unnecessary _connectionAdapters map from the VH.  This needlessly duplicated information already held more generally by the ACO.
* Refactored SessionAdapter in sympathy with CA changes.  SessionsAdapters where _not_ being leaked as the session implementation were already telling the model to delete.

[mcpierce] QPID-5794: Fix the regex in spout.rb

In Ruby > 1.8 the regular expression worked as is. But in 1.8 it
requires that the braces be escaped.

[kgiusti] QPID-5790: avoid use of poll if select is monkey-patched by Eventlet/Greenthreads

[kgiusti] QPID-5773: back out non-functional recv path change from QPID-4872

[aconway] NO-JIRA: HA documentation: security configuration troubleshooting

Common issue for new users is cluster failing to start due to incorrect
security configuration. Added some notes to highlight the need for
security configuration and updated the troubleshooting section.

[kwall] QPID-5782: [Java Broker] Prevent VH housekeeper trying to check the state of queues that are not active

[orudyy] QPID-5413: [Java Broker-Web Management] Allow stopping and starting of virtual host node from the virtual host node tab

[orudyy] QPID-5413: [Java Broker-Web Management] Allow stopping and starting of virtual host nodes and virtual hosts from the broker tab

[kwall] QPID-5791: [Java Broker] Json store should synchronise on update too

[pmoravec] QPID-5748:  [C++ broker] Make Queue::purgeExpired more efficient; remove ExpiryPolicy

[orudyy] QPID-5715: Add new attributes for transaction sync policies into BDB HA virtual host,
           remove 'coalescingSync' attribute from BDB HA virtual host node and always use coalescingSync with replicated environment,
           change attribute 'durability' of  BDB HA virtual host node into derived attribute,
           delegate bdb je transaction creation to EnvironmentFacade,
           with ReplicatedEnvironmentFacade crate transactions with durability having virtual host transaction sync policies
           and ack mode 'SIMPLE_MAJORITY'.

[kwall] NO-JIRA: [Java Broker Tests] Fix race condition in TransactionTimeoutTests meaning observations of test members could yield NPE

* Reordered so that the exception listener's latch is decremented only after members for linked exception message and linked exception code.

[orudyy] QPID-5715: [Java Broker] Fix test BDBHAVirtualHostNodeTest.testTransferMasterToRemoteReplica

[kwall] QPID-5715: [Java Broker] Address review comments from Alex Rudyy

[kwall] QPID-5715: [Java Broker] Added extra logging when transfering master to a remote replica in order to understand sporadic test failure

[orudyy] QPID-5715: On virtual host node deletion delete virtual host first, in order to allow listeners to hear virtual host deletion. JMX Management needs to unregister virtual host MBean on host deletion

[kwall] QPID-5784: [Java Broker] Prevent NPE possibility from BDB store\'s coalescing committer on shutdown

[gsim] QPID-5783: Share immutable state between copies of a message. Avoid using memory for annotations unless actually required.

[robbie] QPID-5048: assembly and dependency fixups

[kwall] QPID-5715: [Java Broker] Prevent sporadic failure of BDB HA REST test testNewMasterElectedWhenVirtualHostIsStopped

* VHN role attribute now mutated after the completion of onMaster/onReplica event
* Made BDBHAReplicaVirtualHost a type (BDB_HA_REPLICA) within the VirtualHost category.  This no-op vhost represents the virtualhost
  when the node is replica (and the mastership is elsewhere within the group).

Work by Andrew MacBean <an...@gmail.com> and me.

[robbie] QPID-5048: restore some config that was erroneously removed previously, update to match current build

[robbie] QPID-5048: make the clients logging test deps explicit rather than just transitive

[robbie] QPID-5781: remove connection from the registry upon exception while closing, ensure we dont loop retrying it

[robbie] QPID-5771: ensure the closed event is passed to the listener even if closing the endpoint input throws something, ensure the connection is unregistered from the connection registry

[kwall] QPID-5779: [Java Broker] JMX plugin Remove debug logging from socket factories

[kwall] QPID-5779:  Workaround sporadic test failure.

It seems sometimes the JMX Plugin's RMI sockets are closed (by the RMI TCP Accept thread) *after* the Broker has stopped.  I can't find a way to avoid this issue. Work around by awaiting the ports to become free within the test.

[kwall] QPID-5779: Add more logging to help understand sporadic test failure.

[kpvdr] NO_JIRA: [linearstore] Update to ISSUES; whitespace fix from last checkin

[kwall] QPID-5779: [Java Broker] JMX plugin's server sockets should set the SO_REUSEADDR socket option - defect fix - set socket option *before* port is bound

[robbie] QPID-5774: remove empty directories

[robbie] NO-JIRA: add a file recording the tests using spawned brokers

[robbie] QPID-5774: remove client plugins dir

[robbie] QPID-5774: remove dependency stubs used for the old pom generation the Ant build did

[robbie] QPID-5774: remove test profile files, custom Ant tasks, resources files specific to the ant build

[robbie] QPID-5774: first main swipe, remove the Ant builds main build.xml and associated files

[kwall] QPID-5779: [Java Broker] JMX plugin's server sockets should set the SO_REUSEADDR socket option

* Plugin now passes correctly configured ServerSocketFactory to JMX for both the registry and connector servers.
* Manually retested SSL connections to JMX.

[pmoravec] no JIRA: [C++ broker] have more descriptive error on parse error of SASL config file

[kwall] QPID-5715: [Java Broker] Make virtualhosts respect the states ACTIVE and STOPPED

* Add state transition tests for BDBHA virtualhostnode / virtualhost
* Prevent the BDBVHN activating the VH (this is now a responsibility of attain desired state)
* BDBHARemoteReplicationNode use state UNAVAILABLE in the case where the remote node is not MASTER or REPLICA.

Work by Andrew MacBean <an...@gmail.com> and me.

[robbie] QPID-5777: delete stale 'doc' directory

[pmoravec] QPID-5767: [C++ broker][linearstore] broker segfaults when recovering journal file with damaged header (Kim's patch)

[kgiusti] QPID-5637: reset Selector singleton across fork.

[kwall] QPID-5715: [Java Broker] Make virtualhosts respect the states ACTIVE and STOPPED

* Changes in virtualhost state are now persisted to store.
* VirtualHostState eliminated.  The PASSIVE state used when a BDB HA Virtualhost is in replica is replaced by UNAVAILABLE.

Work by me and Andrew MacBean <an...@gmail.com>.

[orudyy] QPID-5715: On BDB HA virtual host node deletion invoke ReplicationGroupAdmin#removeMember to remove node from the group

[kwall] NO-JIRA: [Java Broker] Add extra assertions to PortRestTest to help investigate sporadic test failure on some CI environments

[robbie] QPID-5762: log a warning but allow the model processing to continue when there are unsatisfied dependencies, enabling startup if the associated pluggable services are not being used

[kwall] NO-JIRA: Make java-mms test profile ignore org.apache.qpid.server.store.berkeleydb.replication/upgrader sub-packages

[orudyy] QPID-5413: Improve virtual host node and virtual host UI

[kwall] QPID-5766: Intitialisation of StatisticsCounter objects can lead to NPE.

Patch Supplied by Andrew MacBean <an...@gmail.com>.

[kwall] QPID-5554: [Java Broker Documentation] Add logging overview and appendix describing queue alerts

[orudyy] QPID-5715: Fix Virtual Host MBean creation in JMX management plugin

[kwall] QPID-5715: [Java Broker] Make virtualhostnode respect states ACTIVE and STOPPED

* Added test to ensure that the VHN can transit between ACTIVE <=> STOPPED
* Fixed defect whereby the VHN could not be recovered in the STOPPED state.  Added test case.
* Fixed defct whereby on stopping a VHN, the DurableConfigurationStore would be left open.

Work by me and Andrew MacBean <an...@gmail.com>.

[gsim] QPID-5765: don't invoke on dangling pointer

Strictly speaking comparing anything against the old pointer isn't correct either,
but this is harder to change and the only negative effect is that in the event that
a new connection has the same pointer value, it would be incorrectly interpreted
as 'local'.

[kwall] QPID-5715: BDB HA's remote replication nodes were using wrong value for lastKnownReplicationId property

[gsim] QPID-5747: create codec for outgoing connections on establishing the connection, so that any disconnect before we try to write can still be communicated to upper layers

[orudyy] QPID-5744: Add support for REST URIs containing the major version in addition to latest

[orudyy] QPID-5413: Add UI for creation of virtual host nodes

[gsim] QPID-5758: Move purging of expired messages from timer thread to worker thread

[kpvdr] QPID-5750: [linearstore] Broker fails with JERR__AIO: AIO error. (AIO write operation failed: Invalid argument (-22)

[robbie] QPID-5764: update note to reflect the trunk maven build no longer requiring flag to enable

[robbie] QPID-5764: add note detaling the move to the maven build for future releases, to be merged to 0.28 branch

------------------------------------------
[...truncated 7389 lines...]
A         qpid/cpp/bindings/qpid/dotnet/winsdk_sources/msvc10/examples/csharp.example.server/csharp.example.server.csproj
A         qpid/cpp/bindings/qpid/dotnet/winsdk_sources/msvc10/examples/csharp.map.receiver
A         qpid/cpp/bindings/qpid/dotnet/winsdk_sources/msvc10/examples/csharp.map.receiver/csharp.map.receiver.csproj
A         qpid/cpp/bindings/qpid/dotnet/winsdk_sources/msvc10/examples/csharp.example.spout
A         qpid/cpp/bindings/qpid/dotnet/winsdk_sources/msvc10/examples/csharp.example.spout/csharp.example.spout.csproj
A         qpid/cpp/bindings/qpid/dotnet/winsdk_sources/msvc10/examples/csharp.example.helloworld
A         qpid/cpp/bindings/qpid/dotnet/winsdk_sources/msvc10/examples/csharp.example.helloworld/csharp.example.helloworld.csproj
A         qpid/cpp/bindings/qpid/examples
A         qpid/cpp/bindings/qpid/examples/python
AU        qpid/cpp/bindings/qpid/examples/python/spout
AU        qpid/cpp/bindings/qpid/examples/python/drain
A         qpid/cpp/bindings/qpid/examples/python/statistics.py
AU        qpid/cpp/bindings/qpid/examples/python/console
AU        qpid/cpp/bindings/qpid/examples/python/hello
AU        qpid/cpp/bindings/qpid/examples/python/hello_xml
AU        qpid/cpp/bindings/qpid/examples/python/server
A         qpid/cpp/bindings/qpid/examples/perl
AU        qpid/cpp/bindings/qpid/examples/perl/server.pl
AU        qpid/cpp/bindings/qpid/examples/perl/hello_world.pl
AU        qpid/cpp/bindings/qpid/examples/perl/spout.pl
AU        qpid/cpp/bindings/qpid/examples/perl/drain.pl
AU        qpid/cpp/bindings/qpid/examples/perl/map_sender.pl
AU        qpid/cpp/bindings/qpid/examples/perl/client.pl
AU        qpid/cpp/bindings/qpid/examples/perl/map_receiver.pl
AU        qpid/cpp/bindings/qpid/examples/perl/hello_xml.pl
A         qpid/cpp/bindings/qpid/python
A         qpid/cpp/bindings/qpid/python/extra_dist
A         qpid/cpp/bindings/qpid/python/extra_dist/CMakeLists.txt
A         qpid/cpp/bindings/qpid/python/ChangeLog
A         qpid/cpp/bindings/qpid/python/CMakeLists.txt
A         qpid/cpp/bindings/qpid/python/README
A         qpid/cpp/bindings/qpid/python/qpid_messaging.i
A         qpid/cpp/bindings/qpid/python/LICENSE
A         qpid/cpp/bindings/qpid/ruby
A         qpid/cpp/bindings/qpid/ruby/.gitignore
A         qpid/cpp/bindings/qpid/ruby/TODO
A         qpid/cpp/bindings/qpid/ruby/lib
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging/encoding.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging/connection.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging/sender.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging/session.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging/message.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging/receiver.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging/address.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging/duration.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid_messaging.rb
A         qpid/cpp/bindings/qpid/ruby/lib/qpid
A         qpid/cpp/bindings/qpid/ruby/ChangeLog
A         qpid/cpp/bindings/qpid/ruby/ruby.i
A         qpid/cpp/bindings/qpid/ruby/spec
A         qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging
A         qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging/connection_spec.rb
A         qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging/sender_spec.rb
A         qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging/session_spec.rb
A         qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging/message_spec.rb
A         qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging/receiver_spec.rb
A         qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging/address_spec.rb
A         qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging/duration_spec.rb
AU        qpid/cpp/bindings/qpid/ruby/spec/qpid_messaging/encoding_spec.rb
A         qpid/cpp/bindings/qpid/ruby/spec/spec_helper.rb
A         qpid/cpp/bindings/qpid/ruby/spec/qpid
A         qpid/cpp/bindings/qpid/ruby/qpid_messaging.gemspec
A         qpid/cpp/bindings/qpid/ruby/CMakeLists.txt
A         qpid/cpp/bindings/qpid/ruby/examples
A         qpid/cpp/bindings/qpid/ruby/examples/hello_world.rb
A         qpid/cpp/bindings/qpid/ruby/examples/spout.rb
A         qpid/cpp/bindings/qpid/ruby/examples/drain.rb
A         qpid/cpp/bindings/qpid/ruby/examples/map_sender.rb
A         qpid/cpp/bindings/qpid/ruby/examples/client.rb
A         qpid/cpp/bindings/qpid/ruby/examples/map_receiver.rb
A         qpid/cpp/bindings/qpid/ruby/examples/server.rb
A         qpid/cpp/bindings/qpid/ruby/features
A         qpid/cpp/bindings/qpid/ruby/features/sending_a_message.feature
A         qpid/cpp/bindings/qpid/ruby/features/creating_a_sender.feature
A         qpid/cpp/bindings/qpid/ruby/features/sessions_have_names.feature
A         qpid/cpp/bindings/qpid/ruby/features/step_definitions
A         qpid/cpp/bindings/qpid/ruby/features/step_definitions/session_steps.rb
A         qpid/cpp/bindings/qpid/ruby/features/step_definitions/receiver_steps.rb
A         qpid/cpp/bindings/qpid/ruby/features/step_definitions/address_steps.rb
A         qpid/cpp/bindings/qpid/ruby/features/step_definitions/connection_steps.rb
A         qpid/cpp/bindings/qpid/ruby/features/step_definitions/sender_steps.rb
A         qpid/cpp/bindings/qpid/ruby/features/closing_a_connection.feature
A         qpid/cpp/bindings/qpid/ruby/features/connecting_to_a_broker.feature
A         qpid/cpp/bindings/qpid/ruby/features/creating_a_session.feature
A         qpid/cpp/bindings/qpid/ruby/features/receiving_a_message.feature
A         qpid/cpp/bindings/qpid/ruby/features/creating_a_receiver.feature
A         qpid/cpp/bindings/qpid/ruby/features/closing_a_session.feature
A         qpid/cpp/bindings/qpid/ruby/features/support
A         qpid/cpp/bindings/qpid/ruby/features/support/env.rb
A         qpid/cpp/bindings/qpid/ruby/features/session_returns_its_connection.feature
A         qpid/cpp/bindings/qpid/ruby/features/getting_the_connections_authenticated_username.feature
A         qpid/cpp/bindings/qpid/ruby/ext
A         qpid/cpp/bindings/qpid/ruby/ext/cqpid
A         qpid/cpp/bindings/qpid/ruby/ext/cqpid/extconf.rb
A         qpid/cpp/bindings/qpid/ruby/LICENSE
A         qpid/cpp/bindings/qpid/ruby/README.rdoc
A         qpid/cpp/bindings/qpid/perl
A         qpid/cpp/bindings/qpid/perl/perl.i
A         qpid/cpp/bindings/qpid/perl/Makefile.PL.in
A         qpid/cpp/bindings/qpid/perl/CMakeLists.txt
A         qpid/cpp/bindings/qpid/perl/README
A         qpid/cpp/bindings/qpid/perl/test
A         qpid/cpp/bindings/qpid/perl/LICENSE
A         qpid/cpp/bindings/qpid/perl/t
A         qpid/cpp/bindings/qpid/perl/t/utils.pm
A         qpid/cpp/bindings/qpid/perl/t/Message.t
A         qpid/cpp/bindings/qpid/perl/t/Address.t
A         qpid/cpp/bindings/qpid/perl/t/Duration.t
A         qpid/cpp/bindings/qpid/perl/lib
A         qpid/cpp/bindings/qpid/perl/lib/qpid_messaging.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging/Connection.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging/Sender.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging/Session.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging/Message.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging/Receiver.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging/Address.pm
A         qpid/cpp/bindings/qpid/perl/lib/qpid/messaging/Duration.pm
A         qpid/cpp/bindings/qpid/perl/ChangeLog
A         qpid/cpp/bindings/qpid/perl/Makefile.PL
A         qpid/cpp/bindings/qmf
A         qpid/cpp/bindings/qmf/python
A         qpid/cpp/bindings/qmf/ruby
A         qpid/cpp/bindings/qmf/tests
A         qpid/cpp/bindings/qmf2
A         qpid/cpp/bindings/qmf2/examples
A         qpid/cpp/bindings/qmf2/examples/python
AU        qpid/cpp/bindings/qmf2/examples/python/agent.py
A         qpid/cpp/bindings/qmf2/examples/python/find_agents.py
A         qpid/cpp/bindings/qmf2/examples/ruby
A         qpid/cpp/bindings/qmf2/examples/ruby/agent_internal.rb
A         qpid/cpp/bindings/qmf2/examples/ruby/agent_external.rb
A         qpid/cpp/bindings/qmf2/examples/ruby/find_agents.rb
A         qpid/cpp/bindings/qmf2/examples/cpp
A         qpid/cpp/bindings/qmf2/examples/cpp/event_driven_list_agents.cpp
AU        qpid/cpp/bindings/qmf2/examples/cpp/README.txt
AU        qpid/cpp/bindings/qmf2/examples/cpp/CMakeLists.txt
A         qpid/cpp/bindings/qmf2/examples/cpp/list_agents.cpp
A         qpid/cpp/bindings/qmf2/examples/cpp/agent.cpp
A         qpid/cpp/bindings/qmf2/examples/cpp/print_events.cpp
A         qpid/cpp/bindings/qmf2/python
A         qpid/cpp/bindings/qmf2/python/qmf2.py
A         qpid/cpp/bindings/qmf2/python/CMakeLists.txt
A         qpid/cpp/bindings/qmf2/python/cqmf2.i
A         qpid/cpp/bindings/qmf2/ruby
A         qpid/cpp/bindings/qmf2/ruby/qmf2.rb
A         qpid/cpp/bindings/qmf2/ruby/ruby.i
A         qpid/cpp/bindings/qmf2/ruby/CMakeLists.txt
A         qpid/cpp/INSTALL-WINDOWS
A         qpid/cpp/bld-winsdk.ps1
A         qpid/cpp/SSL
AU        qpid/cpp/README-HA.txt
A         qpid/packaging
A         qpid/packaging/windows
A         qpid/packaging/windows/qpidc.wxs
A         qpid/packaging/windows/INSTALL_NOTES.html
A         qpid/packaging/windows/build_installer.bat
AU        qpid/packaging/windows/qpid-install-banner.bmp
AU        qpid/packaging/windows/installer.proj
AU        qpid/packaging/windows/qpid-install-background.bmp
A         qpid/packaging/windows/LICENSE.rtf
AU        qpid/packaging/windows/qpid-icon.ico
 U        .
At revision 1607953
[trunk] $ mvn -f qpid/java/pom.xml -DskipTests=true clean package
[INFO] Scanning for projects...
[INFO] Reactor build order: 
[INFO]   Qpid Java Build
[INFO]   Qpid AMQP 1.0 Common
[INFO]   Qpid AMQP 1.0 Client
[INFO]   Qpid AMQP 1.0 Client JMS
[INFO]   Qpid AMQP 1.0 Client WebSocket
[INFO]   Qpid Broker Code Generation
[INFO]   Qpid Test Utilities
[INFO]   Qpid Common
[INFO]   Qpid Management Common
[INFO]   Qpid Java Broker Core
[INFO]   Qpid Access Control Broker Plug-in
[INFO]   Qpid AMQP 0-8 Protocol Broker Plug-in
[INFO]   Qpid AMQP 0-10 Protocol Plug-in
[INFO]   Qpid AMQP 1-0 Protocol Broker Plug-in
[INFO]   Qpid AMQP 0-8 to 0-10 Message Conversion Broker Plug-in
[INFO]   Qpid AMQP 0-8 to 1-0 Message Conversion Broker Plug-in
[INFO]   Qpid AMQP 0-10 to 1-0 Message Conversion Broker Plug-in
[INFO]   Qpid Derby Message Store
[INFO]   Qpid JDBC Message Store Connection Pooling Plug-in
[INFO]   Qpid JDBC Message Store Broker Plug-in
[INFO]   Qpid HTTP Management Broker Plug-in
[INFO]   Qpid JMX Management Broker Plug-in
[INFO]   Qpid Memory Message Store Broker Plug-in
[INFO]   Qpid AMQP 0-x JMS Client
[INFO]   Qpid BDB Message Store
[INFO]   Qpid BDB Message Store JMX
[INFO]   Qpid Java Broker
[INFO]   Qpid AMQP Management Protocol Broker Plug-in
[INFO]   Qpid WebSocket Broker Plug-in
[INFO]   Qpid AMQP 0-x JMS Client Examples
[INFO]   Qpid JCA
[INFO]   Qpid Resource Adaptor
[INFO]   Qpid Tools
[INFO]   Qpid Management Examples
[INFO]   Qpid Java System Test Parent
[INFO]   Qpid System Tests
[INFO]   Qpid Performance Tests
[INFO]   Qpid Performance Test System Tests
[INFO]   Qpid Performance Tests Visualisation JFC
[INFO]   Qpid BDB Store System Tests
[INFO] ------------------------------------------------------------------------
[INFO] Building Qpid Java Build
[INFO]    task-segment: [clean, package]
[INFO] ------------------------------------------------------------------------
[INFO] [clean:clean {execution: default-clean}]
[INFO] [antrun:run {execution: output-test-properties}]
[INFO] Executing tasks

main:
     [echo] Qpid Test Profile Properties
     [echo] [profile] java-mms.0-10
     [echo] [profile.broker.language] java
     [echo] [profile.broker.type] internal
     [echo] [profile.broker.command] "<https://builds.apache.org/job/Qpid-Java-Artefact-Release/ws/trunk/qpid/java/bin/qpid-server"> -sp @STORE_PATH -st @STORE_TYPE -l @LOG_CONFIG_FILE
     [echo] [profile.specific.excludes] JavaTransientExcludes Java010Excludes
     [echo] [profile.test.excludes] Excludes JavaExcludes java-mms.0-10.excludes JavaTransientExcludes Java010Excludes
     [echo] [profile.broker.version] v0_10
     [echo] [profile.qpid.broker_default_amqp_protocol_excludes] AMQP_1_0
     [echo] [profile.broker.persistent] false
     [echo] [profile.virtualhostnode.type] Memory
     [echo] [profile.virtualhostnode.context.blueprint] {"type":"ProvidedStore"}
[INFO] Executed tasks
[INFO] [enforcer:enforce {execution: enforce-minimum-versions}]
[WARNING] Rule 1: org.apache.maven.plugins.enforcer.RequireMavenVersion failed with message:
Detected Maven Version: 2.2.1 is not in the allowed range 3.0.0.
[INFO] ------------------------------------------------------------------------
[ERROR] BUILD ERROR
[INFO] ------------------------------------------------------------------------
[INFO] Some Enforcer rules have failed. Look above for specific messages explaining why the rule failed.
[INFO] ------------------------------------------------------------------------
[INFO] For more information, run Maven with the -e switch
[INFO] ------------------------------------------------------------------------
[INFO] Total time: 4 seconds
[INFO] Finished at: Fri Jul 04 22:19:46 UTC 2014
[INFO] Final Memory: 24M/177M
[INFO] ------------------------------------------------------------------------
Build step 'Invoke top-level Maven targets' marked build as failure
Archiving artifacts

Jenkins build is back to normal : Qpid-Java-Artefact-Release #1129

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/Qpid-Java-Artefact-Release/1129/>