You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@stratos.apache.org by Rajkumar Rajaratnam <ra...@wso2.com> on 2014/10/01 05:21:10 UTC

Re: Testing Update - 4.1.0-M1

Hi,

CEP extension is throwing following exception when it is trying to publish
member fault event.


TID: [0] [STRATOS] [2014-10-01 08:45:44,863]  INFO
{org.apache.stratos.cep.extension.FaultHandlingWindowProcessor} -  Faulty
member detected [member-id]
test2.php.domain813735f7-c8e3-4281-a727-4e8170522596 with [last time-stamp]
1412133277300 [time-out] 60000 milliseconds
{org.apache.stratos.cep.extension.FaultHandlingWindowProcessor}
TID: [0] [STRATOS] [2014-10-01 08:45:44,864]  INFO
{org.apache.stratos.cep.extension.FaultHandlingWindowProcessor} -
 Publishing member fault event for [member-id]
test2.php.domain813735f7-c8e3-4281-a727-4e8170522596
{org.apache.stratos.cep.extension.FaultHandlingWindowProcessor}
TID: [0] [STRATOS] [2014-10-01 08:45:44,865] ERROR
{org.apache.stratos.cep.extension.FaultHandlingWindowProcessor} -
 org.apache.stratos.messaging.broker.publish.EventPublisher.publish(Ljava/lang/Object;Ljava/util/Properties;Z)V
{org.apache.stratos.cep.extension.FaultHandlingWindowProcessor}
java.lang.NoSuchMethodError:
org.apache.stratos.messaging.broker.publish.EventPublisher.publish(Ljava/lang/Object;Ljava/util/Properties;Z)V
at
org.apache.stratos.cep.extension.FaultHandlingWindowProcessor.publishMemberFault(FaultHandlingWindowProcessor.java:208)
at
org.apache.stratos.cep.extension.FaultHandlingWindowProcessor.run(FaultHandlingWindowProcessor.java:225)
at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:441)
at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
at java.util.concurrent.FutureTask.run(FutureTask.java:138)
at
java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$301(ScheduledThreadPoolExecutor.java:98)
at
java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:207)
at
java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:885)
at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:907)
at java.lang.Thread.run(Thread.java:619)

Thanks

On Wed, Oct 1, 2014 at 2:51 AM, Akila Ravihansa Perera <ra...@wso2.com>
wrote:

> Hi,
>
> There was a regression issue caused by fix for STRATOS-849 that caused
> LB cartridge to be treated as a service cartridge [1]. This is fixed
> now. The reason was "load.balancer.ref" property was missing in LB
> cartridge when processing in LBCreationSubscriptionFilter.
>
> Therefore I created a separate Properties object to hold the
> Properties that gets returned from LBCreationSubscriptionFilter
> process method. Only "lbClusterId" property was added to the returned
> Properties object in LBCreationSubscriptionFilter. Adding all the
> properties will not work since for normal service cartridges, it
> should not add "load.balancer.ref" property.
>
> [1] https://issues.apache.org/jira/browse/STRATOS-852
>
> Thanks.
>
> On Tue, Sep 30, 2014 at 10:52 PM, Rajkumar Rajaratnam
> <ra...@wso2.com> wrote:
> > It seems that the docker image with latest agent is not working properly.
> > Pods are on waiting state for a long time. I replaced with the old image
> and
> > it is working.
> >
> > With the old image, agent is publishing instance activated event, but I
> > didn't get any member started or activated events in the stratos log.
> May be
> > because of I am using old agent.
> >
> > Sajith, can we update the php docker image?
> >
> > Thanks.
> >
> > On Tue, Sep 30, 2014 at 9:44 PM, Sajith Kariyawasam <sa...@wso2.com>
> wrote:
> >>
> >> When testing VM scenarios we faced with an issue that when LB is
> defined,
> >> the service cartridge also spin as an LB.
> >> https://issues.apache.org/jira/browse/STRATOS-849 and were able to get
> >> that fixed.
> >>
> >> Now the instances are created and member activated events are also
> >> received, but when trying to access through LB I'm getting an error in
> the
> >> browser as
> >> "Unknown host name <php102sajith.stratos.com>".
> >>
> >> Also in stratos log I could see the following exception, seems there is
> an
> >> issue when publishing stats to MB.
> >>
> >> I'm Looking into those now
> >>
> >> TID: [0] [STRATOS] [2014-09-30 15:45:26,252]  INFO
> >>
> {org.wso2.carbon.event.output.adaptor.jms.internal.util.JMSConnectionFactory}
> >> -  JMS ConnectionFactory : JMSOutputAdaptor initialized
> >>
> {org.wso2.carbon.event.output.adaptor.jms.internal.util.JMSConnectionFactory}
> >> TID: [0] [STRATOS] [2014-09-30 15:45:26,244] ERROR
> >>
> {org.wso2.carbon.event.output.adaptor.jms.internal.util.JMSConnectionFactory}
> >> -  Error creating JMS session from JMS CF : JMSOutputAdaptor
> >>
> {org.wso2.carbon.event.output.adaptor.jms.internal.util.JMSConnectionFactory}
> >> javax.jms.JMSException: Cannot send, channel has already failed:
> >> tcp://10.172.137.89:1883
> >>         at
> >>
> org.apache.activemq.util.JMSExceptionSupport.create(JMSExceptionSupport.java:72)
> >>         at
> >>
> org.apache.activemq.ActiveMQConnection.syncSendPacket(ActiveMQConnection.java:1426)
> >>         at
> >>
> org.apache.activemq.ActiveMQConnection.ensureConnectionInfoSent(ActiveMQConnection.java:1513)
> >>         at
> >>
> org.apache.activemq.ActiveMQConnection.createSession(ActiveMQConnection.java:327)
> >>         at
> >>
> org.wso2.carbon.event.output.adaptor.jms.internal.util.JMSUtils.createSession(JMSUtils.java:449)
> >>         at
> >>
> org.wso2.carbon.event.output.adaptor.jms.internal.util.JMSConnectionFactory.createSession(JMSConnectionFactory.java:339)
> >>         at
> >>
> org.wso2.carbon.event.output.adaptor.jms.internal.util.JMSConnectionFactory.getSession(JMSConnectionFactory.java:393)
> >>         at
> >>
> org.wso2.carbon.event.output.adaptor.jms.internal.util.JMSMessageSender.<init>(JMSMessageSender.java:103)
> >>         at
> >>
> org.wso2.carbon.event.output.adaptor.jms.JMSEventAdaptorType.initPublisher(JMSEventAdaptorType.java:214)
> >>         at
> >>
> org.wso2.carbon.event.output.adaptor.jms.JMSEventAdaptorType.publish(JMSEventAdaptorType.java:191)
> >>         at
> >>
> org.wso2.carbon.event.output.adaptor.core.AbstractOutputEventAdaptor.publishCall(AbstractOutputEventAdaptor.java:123)
> >>         at
> >>
> org.wso2.carbon.event.output.adaptor.core.internal.CarbonOutputEventAdaptorService.publish(CarbonOutputEventAdaptorService.java:90)
> >>         at
> >>
> org.wso2.carbon.event.formatter.core.config.EventFormatter.sendEventData(EventFormatter.java:168)
> >>         at
> >>
> org.wso2.carbon.event.formatter.core.EventFormatterSender.sendEventData(EventFormatterSender.java:36)
> >>         at
> >>
> org.wso2.carbon.event.processor.core.internal.listener.ExternalStreamConsumer.consumeEvents(ExternalStreamConsumer.java:43)
> >>         at
> >>
> org.wso2.carbon.event.processor.core.internal.stream.EventJunction.dispatchEvents(EventJunction.java:85)
> >>         at
> >>
> org.wso2.carbon.event.processor.core.internal.listener.SiddhiOutputStreamListener.receive(SiddhiOutputStreamListener.java:77)
> >>         at
> >>
> org.wso2.siddhi.core.stream.output.StreamCallback.send(StreamCallback.java:83)
> >>         at
> >>
> org.wso2.siddhi.core.stream.output.StreamCallback.receive(StreamCallback.java:56)
> >>         at
> >> org.wso2.siddhi.core.stream.StreamJunction.send(StreamJunction.java:45)
> >>         at
> >>
> org.wso2.siddhi.core.query.output.callback.InsertIntoStreamCallback.send(InsertIntoStreamCallback.java:35)
> >>         at
> >>
> org.wso2.siddhi.core.query.output.ratelimit.OutputRateManager.sendToCallBacks(OutputRateManager.java:38)
> >>         at
> >>
> org.wso2.siddhi.core.query.output.ratelimit.PassThroughOutputRateManager.send(PassThroughOutputRateManager.java:26)
> >>         at
> >>
> org.wso2.siddhi.core.query.selector.QuerySelector.process(QuerySelector.java:221)
> >>         at
> >>
> org.wso2.siddhi.core.query.selector.QuerySelector.process(QuerySelector.java:275)
> >>         at
> >>
> org.wso2.siddhi.core.query.processor.window.TimeBatchWindowProcessor.run(TimeBatchWindowProcessor.java:113)
> >>         at
> >> java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:471)
> >>         at java.util.concurrent.FutureTask.run(FutureTask.java:262)
> >>         at
> >>
> java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$201(ScheduledThreadPoolExecutor.java:178)
> >>         at
> >>
> java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:292)
> >>         at
> >>
> java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
> >>         at
> >>
> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
> >>         at java.lang.Thread.run(Thread.java:745)
> >> Caused by: org.apache.activemq.transport.InactivityIOException: Cannot
> >> send, channel has already failed: tcp://10.172.137.89:1883
> >>         at
> >>
> org.apache.activemq.transport.AbstractInactivityMonitor.doOnewaySend(AbstractInactivityMonitor.java:297)
> >>         at
> >>
> org.apache.activemq.transport.AbstractInactivityMonitor.oneway(AbstractInactivityMonitor.java:286)
> >>         at
> >>
> org.apache.activemq.transport.TransportFilter.oneway(TransportFilter.java:85)
> >>         at
> >>
> org.apache.activemq.transport.WireFormatNegotiator.oneway(WireFormatNegotiator.java:104)
> >>         at
> >>
> org.apache.activemq.transport.MutexTransport.oneway(MutexTransport.java:68)
> >>
> >>
> >> On Tue, Sep 30, 2014 at 10:13 AM, Gayan Gunarathne <ga...@wso2.com>
> >> wrote:
> >>>
> >>> I have fixed this issue and made a pull request for this.
> >>> https://github.com/apache/stratos/pull/72
> >>>
> >>> This is happen due to we try to process instance status events in the
> >>> cartridge events. We don't need to process instance status events in
> the
> >>> cartridge end as they are published with the cartridge agent.
> >>>
> >>> Thanks,
> >>> Gayan
> >>>
> >>>
> >>>
> >>> On Mon, Sep 29, 2014 at 9:25 PM, Rajkumar Rajaratnam <
> rajkumarr@wso2.com>
> >>> wrote:
> >>>>
> >>>> Hi,
> >>>>
> >>>> We have sorted out agent issues. Now the container is activated
> >>>> successfully. We can see the active members in stratos admin console.
> There
> >>>> is one more error to be sorted out. Pasted the agent log here.
> >>>>
> >>>> [2014-09-29 15:45:56,378]  INFO - [CartridgeAgent] Waiting for
> Cartridge
> >>>> Agent to be initialized...
> >>>> [2014-09-29 15:45:57,380]  INFO - [CartridgeAgent] Waiting for
> Cartridge
> >>>> Agent to be initialized...
> >>>> [2014-09-29 15:45:58,381]  INFO - [CartridgeAgent] Waiting for
> Cartridge
> >>>> Agent to be initialized...
> >>>> [2014-09-29 15:45:59,383]  INFO - [CartridgeAgent] Waiting for
> Cartridge
> >>>> Agent to be initialized...
> >>>> [2014-09-29 15:46:00,384]  INFO - [CartridgeAgent] Waiting for
> Cartridge
> >>>> Agent to be initialized...
> >>>> [2014-09-29 15:46:00,914]  INFO - [CompleteTenantMessageProcessor]
> >>>> Tenant initialized
> >>>> [2014-09-29 15:46:00,950]  INFO - [CompleteTopologyMessageProcessor]
> >>>> Topology initialized
> >>>> [2014-09-29 15:46:01,390]  INFO - [CartridgeAgentEventPublisher]
> >>>> Publishing instance started event
> >>>> [2014-09-29 15:46:01,404] ERROR -
> >>>> [InstanceNotifierEventMessageDelegator] Failed to retrieve instance
> notifier
> >>>> event message
> >>>> java.lang.RuntimeException: Failed to process instance clean up using
> >>>> available message processors: [type]
> >>>>
> org.apache.stratos.messaging.event.instance.status.InstanceStartedEvent
> >>>> [body]
> >>>>
> {"serviceName":"php","clusterId":"test2.php.domain","networkPartitionId":"somes","partitionId":"some","memberId":"test2.php.domain3509c97b-a567-4a0a-b234-e66c162cf10a"}
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.processor.instance.notifier.InstanceCleanupClusterNotifierMessageProcessor.process(InstanceCleanupClusterNotifierMessageProcessor.java:51)
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.processor.instance.notifier.InstanceCleanupMemberNotifierMessageProcessor.process(InstanceCleanupMemberNotifierMessageProcessor.java:48)
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.processor.instance.notifier.ArtifactUpdateMessageProcessor.process(ArtifactUpdateMessageProcessor.java:54)
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.processor.MessageProcessorChain.process(MessageProcessorChain.java:60)
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.receiver.instance.notifier.InstanceNotifierEventMessageDelegator.run(InstanceNotifierEventMessageDelegator.java:76)
> >>>> at java.lang.Thread.run(Thread.java:722)
> >>>> [2014-09-29 15:46:01,419]  INFO - [CartridgeAgentEventPublisher]
> >>>> Instance started event published
> >>>> [2014-09-29 15:46:01,419]  INFO - [DefaultExtensionHandler] [start
> >>>> server extension] complete topology event received
> >>>> [2014-09-29 15:46:01,441]  INFO - [CartridgeAgentUtils] Waiting for
> >>>> ports to be active: [ip] localhost [ports] [80]
> >>>> [2014-09-29 15:46:06,444]  INFO - [CartridgeAgentUtils] Ports
> activated:
> >>>> [ip] localhost [ports] [80]
> >>>> [2014-09-29 15:46:06,446]  INFO - [CartridgeAgent] No artifact
> >>>> repository found
> >>>> [2014-09-29 15:46:06,480]  INFO - [CartridgeAgentEventPublisher]
> >>>> Publishing instance activated event
> >>>> [2014-09-29 15:46:06,496] ERROR -
> >>>> [InstanceNotifierEventMessageDelegator] Failed to retrieve instance
> notifier
> >>>> event message
> >>>> java.lang.RuntimeException: Failed to process instance clean up using
> >>>> available message processors: [type]
> >>>>
> org.apache.stratos.messaging.event.instance.status.InstanceActivatedEvent
> >>>> [body]
> >>>>
> {"serviceName":"php","clusterId":"test2.php.domain","networkPartitionId":"somes","partitionId":"some","memberId":"test2.php.domain3509c97b-a567-4a0a-b234-e66c162cf10a"}
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.processor.instance.notifier.InstanceCleanupClusterNotifierMessageProcessor.process(InstanceCleanupClusterNotifierMessageProcessor.java:51)
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.processor.instance.notifier.InstanceCleanupMemberNotifierMessageProcessor.process(InstanceCleanupMemberNotifierMessageProcessor.java:48)
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.processor.instance.notifier.ArtifactUpdateMessageProcessor.process(ArtifactUpdateMessageProcessor.java:54)
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.processor.MessageProcessorChain.process(MessageProcessorChain.java:60)
> >>>> at
> >>>>
> org.apache.stratos.messaging.message.receiver.instance.notifier.InstanceNotifierEventMessageDelegator.run(InstanceNotifierEventMessageDelegator.java:76)
> >>>> at java.lang.Thread.run(Thread.java:722)
> >>>> [2014-09-29 15:46:06,500]  INFO - [CartridgeAgentEventPublisher]
> >>>> Instance activated event published
> >>>> [2014-09-29 15:46:06,500]  INFO - [CartridgeAgentEventPublisher]
> >>>> Starting health statistics notifier
> >>>> [2014-09-29 15:46:06,544]  INFO - [CartridgeAgentEventPublisher]
> Health
> >>>> statistics notifier started
> >>>>
> >>>> Thanks.
> >>>>
> >>>> On Mon, Sep 29, 2014 at 8:07 PM, Akila Ravihansa Perera
> >>>> <ra...@wso2.com> wrote:
> >>>>>
> >>>>> Hi all,
> >>>>>
> >>>>> Kubernetes host registration issue is fixed in master branch now.
> This
> >>>>> was due to an merge conflict that occurred while merging with
> >>>>> docker-integration branch.
> >>>>>
> >>>>> Thanks.
> >>>>>
> >>>>> On Sun, Sep 28, 2014 at 12:07 PM, Rajkumar Rajaratnam
> >>>>> <ra...@wso2.com> wrote:
> >>>>> > Hi Gayan,
> >>>>> >
> >>>>> > On TopicSubscriber.doSubscribe() method, don't we have to set the
> >>>>> > variable
> >>>>> > "subscribed" to true once the subscription succeeded?
> >>>>> >
> >>>>> > Thanks.
> >>>>> >
> >>>>> >
> >>>>> > On Sat, Sep 27, 2014 at 9:09 PM, Sajith Kariyawasam <
> sajith@wso2.com>
> >>>>> > wrote:
> >>>>> >>
> >>>>> >>
> >>>>> >>
> >>>>> >> On Sat, Sep 27, 2014 at 8:17 PM, Rajkumar Rajaratnam
> >>>>> >> <ra...@wso2.com>
> >>>>> >> wrote:
> >>>>> >>>
> >>>>> >>> Hi,
> >>>>> >>>
> >>>>> >>> Cartridge Agent didn't start topology event receiver thread.
> There
> >>>>> >>> is no
> >>>>> >>> log regarding this. But CA starts instance notifier listener
> thread
> >>>>> >>> and
> >>>>> >>> tenant event receiver thread. There are logs for this.
> >>>>> >>>
> >>>>> >> Strange!, topology event listener method gets invoked before
> tenant
> >>>>> >> event
> >>>>> >> receiver, so it should at least print the log .. may be a thread
> >>>>> >> sleep
> >>>>> >> issue? I will have a look into this..
> >>>>> >>
> >>>>> >>>
> >>>>> >>> If CA starts topology event receiver thread, there should be a
> log
> >>>>> >>> "Starting topology event message receiver thread". It is not
> there.
> >>>>> >>> That is
> >>>>> >>> why it didn't get the topology events. I couldn't debug because I
> >>>>> >>> can't ping
> >>>>> >>> from my local machine to container.
> >>>>> >>>
> >>>>> >>> Thanks.
> >>>>> >>>
> >>>>> >>> On Sat, Sep 27, 2014 at 4:39 PM, Gayan Gunarathne <
> gayang@wso2.com>
> >>>>> >>> wrote:
> >>>>> >>>>
> >>>>> >>>> Hi Raj,
> >>>>> >>>>
> >>>>> >>>> Seems like that cartridge agent is not initiated.Are we
> receiving
> >>>>> >>>> the
> >>>>> >>>> "CompleteTopologyEvent" event.
> >>>>> >>>> AFAIU cartridge agent set to initiated based on the complete
> >>>>> >>>> topology
> >>>>> >>>> event consistency.
> >>>>> >>>>
> >>>>> >>>> Thanks,
> >>>>> >>>> Gayan
> >>>>> >>>>
> >>>>> >>>> On Sat, Sep 27, 2014 at 3:48 PM, Rajkumar Rajaratnam
> >>>>> >>>> <ra...@wso2.com> wrote:
> >>>>> >>>>>
> >>>>> >>>>> Hi,
> >>>>> >>>>>
> >>>>> >>>>> Now cartridge agent is starting up successfully. But It is not
> >>>>> >>>>> publishing any events. Here is the agent log.
> >>>>> >>>>>
> >>>>> >>>>> Starting cartridge agent...
> >>>>> >>>>> [2014-09-27 10:14:44,902] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> Cannot
> >>>>> >>>>> read log file path : Cannot find the value of required
> parameter:
> >>>>> >>>>> LOG_FILE_PATHS
> >>>>> >>>>> [2014-09-27 10:14:44,905] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> Cannot
> >>>>> >>>>> read persistence mapping : Cannot find the value of required
> >>>>> >>>>> parameter:
> >>>>> >>>>> PERSISTENCE_MAPPING
> >>>>> >>>>> [2014-09-27 10:14:44,906]  INFO - [CartridgeAgentConfiguration]
> >>>>> >>>>> INTERNAL payload parameter is not found
> >>>>> >>>>> [2014-09-27 10:14:44,907]  INFO - [CartridgeAgentConfiguration]
> >>>>> >>>>> Cartridge agent configuration initialized
> >>>>> >>>>> [2014-09-27 10:14:44,908] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> service-name: php
> >>>>> >>>>> [2014-09-27 10:14:44,908] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> cluster-id: test2.php.domain
> >>>>> >>>>> [2014-09-27 10:14:44,909] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> network-partition-id: null
> >>>>> >>>>> [2014-09-27 10:14:44,909] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> partition-id: null
> >>>>> >>>>> [2014-09-27 10:14:44,910] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> member-id: test2.php.domain12519f82-d7fe-4da6-a0b8-fa714439dd0f
> >>>>> >>>>> [2014-09-27 10:14:44,910] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> cartridge-key: 4vY6vLcBLgkVryBU
> >>>>> >>>>> [2014-09-27 10:14:44,911] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> app-path: APP_PATH
> >>>>> >>>>> [2014-09-27 10:14:44,911] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> repo-url: null
> >>>>> >>>>> [2014-09-27 10:14:44,912] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> ports:
> >>>>> >>>>> [80, 443]
> >>>>> >>>>> [2014-09-27 10:14:44,913] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> lb-private-ip:
> >>>>> >>>>> [2014-09-27 10:14:44,913] DEBUG - [CartridgeAgentConfiguration]
> >>>>> >>>>> lb-public-ip:
> >>>>> >>>>> [2014-09-27 10:14:45,055] DEBUG - [Main] Loading default
> >>>>> >>>>> Cartridge
> >>>>> >>>>> Agent.
> >>>>> >>>>> [2014-09-27 10:14:45,056]  INFO - [CartridgeAgent] Cartridge
> >>>>> >>>>> agent
> >>>>> >>>>> started
> >>>>> >>>>> [2014-09-27 10:14:45,060] DEBUG - [CartridgeAgent] Starting
> >>>>> >>>>> instance
> >>>>> >>>>> notifier event message receiver thread
> >>>>> >>>>> [2014-09-27 10:14:45,067] DEBUG -
> >>>>> >>>>> [InstanceNotifierMessageProcessorChain] Instance notifier
> message
> >>>>> >>>>> processor
> >>>>> >>>>> chain initialized
> >>>>> >>>>> [2014-09-27 10:14:45,070]  INFO - [CartridgeAgent] Instance
> >>>>> >>>>> notifier
> >>>>> >>>>> event message receiver thread started
> >>>>> >>>>> [2014-09-27 10:14:45,071] DEBUG - [CartridgeAgent] Starting
> >>>>> >>>>> tenant
> >>>>> >>>>> event message receiver thread
> >>>>> >>>>> [2014-09-27 10:14:45,077] DEBUG - [TenantMessageProcessorChain]
> >>>>> >>>>> Tenant
> >>>>> >>>>> message processor chain initialized
> >>>>> >>>>> [2014-09-27 10:14:45,078] DEBUG - [TopicSubscriber] Topic
> >>>>> >>>>> subscriber
> >>>>> >>>>> connector created: [topic] instance/#
> >>>>> >>>>> [2014-09-27 10:14:45,079] DEBUG -
> >>>>> >>>>> [InstanceNotifierMessageProcessorChain] Instance notifier
> message
> >>>>> >>>>> processor
> >>>>> >>>>> chain initialized
> >>>>> >>>>> [2014-09-27 10:14:45,080] DEBUG -
> [InstanceNotifierEventReceiver]
> >>>>> >>>>> InstanceNotifier event message receiver thread started
> >>>>> >>>>> [2014-09-27 10:14:45,084] DEBUG -
> [InstanceNotifierEventReceiver]
> >>>>> >>>>> InstanceNotifier event message delegator thread started
> >>>>> >>>>> [2014-09-27 10:14:45,084]  INFO -
> >>>>> >>>>> [InstanceNotifierEventMessageDelegator] Instance notifier event
> >>>>> >>>>> message
> >>>>> >>>>> delegator started
> >>>>> >>>>> [2014-09-27 10:14:45,085]  INFO - [CartridgeAgent] Tenant event
> >>>>> >>>>> message
> >>>>> >>>>> receiver thread started
> >>>>> >>>>> [2014-09-27 10:14:45,085] DEBUG - [TopicSubscriber] Topic
> >>>>> >>>>> subscriber
> >>>>> >>>>> connector created: [topic] tenant/#
> >>>>> >>>>> [2014-09-27 10:14:45,087] DEBUG -
> >>>>> >>>>> [InstanceNotifierMessageProcessorChain] Instance notifier
> message
> >>>>> >>>>> processor
> >>>>> >>>>> chain initialized
> >>>>> >>>>> [2014-09-27 10:14:45,089]  INFO - [CartridgeAgent] Instance
> >>>>> >>>>> notifier
> >>>>> >>>>> event message receiver thread started
> >>>>> >>>>> [2014-09-27 10:14:45,091] DEBUG - [CartridgeAgent] Starting
> >>>>> >>>>> tenant
> >>>>> >>>>> event message receiver thread
> >>>>> >>>>> [2014-09-27 10:14:45,091] DEBUG - [TopicSubscriber] Topic
> >>>>> >>>>> subscriber
> >>>>> >>>>> connector created: [topic] instance/#
> >>>>> >>>>> [2014-09-27 10:14:45,092] DEBUG -
> >>>>> >>>>> [InstanceNotifierMessageProcessorChain] Instance notifier
> message
> >>>>> >>>>> processor
> >>>>> >>>>> chain initialized
> >>>>> >>>>> [2014-09-27 10:14:45,092] DEBUG - [TenantEventReceiver] Tenant
> >>>>> >>>>> event
> >>>>> >>>>> message receiver thread started
> >>>>> >>>>> [2014-09-27 10:14:45,096] DEBUG -
> [InstanceNotifierEventReceiver]
> >>>>> >>>>> InstanceNotifier event message receiver thread started
> >>>>> >>>>> [2014-09-27 10:14:45,097] DEBUG - [TenantEventReceiver] Tenant
> >>>>> >>>>> event
> >>>>> >>>>> message delegator thread started
> >>>>> >>>>> [2014-09-27 10:14:45,103]  INFO - [TenantEventMessageDelegator]
> >>>>> >>>>> Tenant
> >>>>> >>>>> event message delegator started
> >>>>> >>>>> [2014-09-27 10:14:45,107] DEBUG -
> [InstanceNotifierEventReceiver]
> >>>>> >>>>> InstanceNotifier event message delegator thread started
> >>>>> >>>>> [2014-09-27 10:14:45,110]  INFO -
> >>>>> >>>>> [InstanceNotifierEventMessageDelegator] Instance notifier event
> >>>>> >>>>> message
> >>>>> >>>>> delegator started
> >>>>> >>>>> [2014-09-27 10:14:45,134] DEBUG - [MQTTConnector] MQTT client
> >>>>> >>>>> connected
> >>>>> >>>>> [2014-09-27 10:14:45,136] DEBUG - [MQTTConnector] MQTT client
> >>>>> >>>>> connected
> >>>>> >>>>> [2014-09-27 10:14:45,138] DEBUG - [MQTTConnector] MQTT client
> >>>>> >>>>> connected
> >>>>> >>>>> [2014-09-27 10:14:45,164] DEBUG - [TopicSubscriber] Subscribing
> >>>>> >>>>> to
> >>>>> >>>>> topic 'instance/#' from tcp://10.111.11.221:1883
> >>>>> >>>>> [2014-09-27 10:14:45,165] DEBUG - [TopicSubscriber] Subscribing
> >>>>> >>>>> to
> >>>>> >>>>> topic 'tenant/#' from tcp://10.111.11.221:1883
> >>>>> >>>>> [2014-09-27 10:14:45,165] DEBUG - [TopicSubscriber] Subscribing
> >>>>> >>>>> to
> >>>>> >>>>> topic 'instance/#' from tcp://10.111.11.221:1883
> >>>>> >>>>>
> >>>>> >>>>> What would be the issue here?
> >>>>> >>>>>
> >>>>> >>>>> Thanks.
> >>>>> >>>>>
> >>>>> >>>>>
> >>>>> >>>>> On Sat, Sep 27, 2014 at 3:24 PM, Gayan Gunarathne
> >>>>> >>>>> <ga...@wso2.com>
> >>>>> >>>>> wrote:
> >>>>> >>>>>>
> >>>>> >>>>>> mqtttopic.properties file should be as
> >>>>> >>>>>>
> >>>>> >>>>>>
> https://github.com/apache/stratos/blob/docker-integration/products/cartridge-agent/modules/distribution/src/main/conf/mqtttopic.properties
> >>>>> >>>>>>
> >>>>> >>>>>> Thanks,
> >>>>> >>>>>> Gayan
> >>>>> >>>>>>
> >>>>> >>>>>>
> >>>>> >>>>>> On Sat, Sep 27, 2014 at 3:01 PM, Rajkumar Rajaratnam
> >>>>> >>>>>> <ra...@wso2.com> wrote:
> >>>>> >>>>>>>
> >>>>> >>>>>>> Hi,
> >>>>> >>>>>>>
> >>>>> >>>>>>> As per the offline discussion with Gayan, agent's
> >>>>> >>>>>>> mqtttopic.properties is having wrong content as in the
> previous
> >>>>> >>>>>>> mail. But it
> >>>>> >>>>>>> should be like below,
> >>>>> >>>>>>>
> >>>>> >>>>>>> mqtturl=tcp://10.111.11.221:1883
> >>>>> >>>>>>> clientID=stratos
> >>>>> >>>>>>> tempfilelocation=/tmp
> >>>>> >>>>>>>
> >>>>> >>>>>>> Thanks Gayan for the info.
> >>>>> >>>>>>>
> >>>>> >>>>>>> On Sat, Sep 27, 2014 at 2:27 PM, Rajkumar Rajaratnam
> >>>>> >>>>>>> <ra...@wso2.com> wrote:
> >>>>> >>>>>>>>
> >>>>> >>>>>>>> Hi,
> >>>>> >>>>>>>>
> >>>>> >>>>>>>> connectionfactoryName=TopicConnectionFactory
> >>>>> >>>>>>>> java.naming.provider.url=tcp://10.111.11.221:1883
> >>>>> >>>>>>>>
> >>>>> >>>>>>>>
> >>>>> >>>>>>>>
> java.naming.factory.initial=org.apache.activemq.jndi.ActiveMQInitialContextFactory
> >>>>> >>>>>>>>
> >>>>> >>>>>>>> Thanks.
> >>>>> >>>>>>>>
> >>>>> >>>>>>>> On Sat, Sep 27, 2014 at 2:14 PM, Gayan Gunarathne
> >>>>> >>>>>>>> <ga...@wso2.com>
> >>>>> >>>>>>>> wrote:
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>> Hi Raj,
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>> What is the mqtturl specified in the mqtttopic.properties
> >>>>> >>>>>>>>> file?
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>> Thanks,
> >>>>> >>>>>>>>> Gayan
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>> On Sat, Sep 27, 2014 at 1:02 PM, Rajkumar Rajaratnam
> >>>>> >>>>>>>>> <ra...@wso2.com> wrote:
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>> Hi,
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>> Until this is sorted out, I am doing a test in docker
> >>>>> >>>>>>>>>> branch.
> >>>>> >>>>>>>>>> Cartridge Agent is not starting up. It is giving the
> >>>>> >>>>>>>>>> following error. But I
> >>>>> >>>>>>>>>> can telnet to MB from the container.
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>> Starting cartridge agent...
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,260]  INFO -
> >>>>> >>>>>>>>>> [CartridgeAgentConfiguration]
> >>>>> >>>>>>>>>> INTERNAL payload parameter is not found
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,262]  INFO -
> >>>>> >>>>>>>>>> [CartridgeAgentConfiguration]
> >>>>> >>>>>>>>>> Cartridge agent configuration initialized
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,412]  INFO - [CartridgeAgent]
> Cartridge
> >>>>> >>>>>>>>>> agent
> >>>>> >>>>>>>>>> started
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,427]  INFO - [CartridgeAgent]
> Instance
> >>>>> >>>>>>>>>> notifier event message receiver thread started
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,436]  INFO -
> >>>>> >>>>>>>>>> [InstanceNotifierEventMessageDelegator] Instance notifier
> >>>>> >>>>>>>>>> event message
> >>>>> >>>>>>>>>> delegator started
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,443]  INFO - [CartridgeAgent] Tenant
> >>>>> >>>>>>>>>> event
> >>>>> >>>>>>>>>> message receiver thread started
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,443]  INFO - [CartridgeAgent]
> Instance
> >>>>> >>>>>>>>>> notifier event message receiver thread started
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,455]  INFO -
> >>>>> >>>>>>>>>> [TenantEventMessageDelegator]
> >>>>> >>>>>>>>>> Tenant event message delegator started
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,463]  INFO -
> >>>>> >>>>>>>>>> [InstanceNotifierEventMessageDelegator] Instance notifier
> >>>>> >>>>>>>>>> event message
> >>>>> >>>>>>>>>> delegator started
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,464] ERROR - [TopicSubscriber] Error
> >>>>> >>>>>>>>>> while
> >>>>> >>>>>>>>>> subscribing to the topic: instance/#
> >>>>> >>>>>>>>>> java.lang.IllegalArgumentException: defaultValue
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttConnectOptions.validateURI(MqttConnectOptions.java:433)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttAsyncClient.<init>(MqttAsyncClient.java:260)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttClient.<init>(MqttClient.java:222)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.connect.MQTTConnector.getMQTTSubClient(MQTTConnector.java:96)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.subscribe.TopicSubscriber.doSubscribe(TopicSubscriber.java:71)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.subscribe.TopicSubscriber.run(TopicSubscriber.java:118)
> >>>>> >>>>>>>>>> at java.lang.Thread.run(Thread.java:722)
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,465] ERROR - [TopicSubscriber] Error
> >>>>> >>>>>>>>>> while
> >>>>> >>>>>>>>>> subscribing to the topic: tenant/#
> >>>>> >>>>>>>>>> java.lang.IllegalArgumentException: defaultValue
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttConnectOptions.validateURI(MqttConnectOptions.java:433)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttAsyncClient.<init>(MqttAsyncClient.java:260)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttClient.<init>(MqttClient.java:222)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.connect.MQTTConnector.getMQTTSubClient(MQTTConnector.java:96)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.subscribe.TopicSubscriber.doSubscribe(TopicSubscriber.java:71)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.subscribe.TopicSubscriber.run(TopicSubscriber.java:118)
> >>>>> >>>>>>>>>> at java.lang.Thread.run(Thread.java:722)
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,469]  INFO - [TopicSubscriber] Will
> try
> >>>>> >>>>>>>>>> to
> >>>>> >>>>>>>>>> subscribe again in 30 sec
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,470]  INFO - [TopicSubscriber] Will
> try
> >>>>> >>>>>>>>>> to
> >>>>> >>>>>>>>>> subscribe again in 30 sec
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,471] ERROR - [TopicSubscriber] Error
> >>>>> >>>>>>>>>> while
> >>>>> >>>>>>>>>> subscribing to the topic: instance/#
> >>>>> >>>>>>>>>> java.lang.IllegalArgumentException: defaultValue
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttConnectOptions.validateURI(MqttConnectOptions.java:433)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttAsyncClient.<init>(MqttAsyncClient.java:260)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.eclipse.paho.client.mqttv3.MqttClient.<init>(MqttClient.java:222)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.connect.MQTTConnector.getMQTTSubClient(MQTTConnector.java:96)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.subscribe.TopicSubscriber.doSubscribe(TopicSubscriber.java:71)
> >>>>> >>>>>>>>>> at
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> org.apache.stratos.messaging.broker.subscribe.TopicSubscriber.run(TopicSubscriber.java:118)
> >>>>> >>>>>>>>>> at java.lang.Thread.run(Thread.java:722)
> >>>>> >>>>>>>>>> [2014-09-27 07:28:59,476]  INFO - [TopicSubscriber] Will
> try
> >>>>> >>>>>>>>>> to
> >>>>> >>>>>>>>>> subscribe again in 30 sec
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>> Any idea?
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>> On Sat, Sep 27, 2014 at 8:55 AM, Manula Chathurika
> >>>>> >>>>>>>>>> Thantriwatte
> >>>>> >>>>>>>>>> <ma...@wso2.com> wrote:
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>> Hi,
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>> When I merged docker-integration branch with master,
> there
> >>>>> >>>>>>>>>>> are
> >>>>> >>>>>>>>>>> lots of changes in AutoScalerService.wsdl and
> >>>>> >>>>>>>>>>> CloudControllerService.wsdl.
> >>>>> >>>>>>>>>>> So merging wsdl's can cause multiple errors. So what I
> did
> >>>>> >>>>>>>>>>> was, done the
> >>>>> >>>>>>>>>>> code marge in Autoscaler component and build it and
> >>>>> >>>>>>>>>>> generate the wsdl and
> >>>>> >>>>>>>>>>> put it in to service-stubs and rebuild the service stub.
> >>>>> >>>>>>>>>>> After that I'm able
> >>>>> >>>>>>>>>>> to solve all the compilation issues. Have I missed
> anything
> >>>>> >>>>>>>>>>> from that ?
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>> Thanks !
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>> On Sat, Sep 27, 2014 at 1:53 AM, Rajkumar Rajaratnam
> >>>>> >>>>>>>>>>> <ra...@wso2.com> wrote:
> >>>>> >>>>>>>>>>>>
> >>>>> >>>>>>>>>>>> Attached.
> >>>>> >>>>>>>>>>>>
> >>>>> >>>>>>>>>>>> On Sat, Sep 27, 2014 at 1:52 AM, Sajith Kariyawasam
> >>>>> >>>>>>>>>>>> <sa...@wso2.com> wrote:
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>> On Sat, Sep 27, 2014 at 1:40 AM, Sajith Kariyawasam
> >>>>> >>>>>>>>>>>>> <sa...@wso2.com> wrote:
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>> Seems to have a mismatch of argument types expects
> from
> >>>>> >>>>>>>>>>>>>> the
> >>>>> >>>>>>>>>>>>>> AutoscalerService.
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>> Could you please attach the wsdl of the
> >>>>> >>>>>>>>>>>>>> AutoscalerService once
> >>>>> >>>>>>>>>>>>>> you access the service as follows
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>> https://
> <stratos-server>:<port>/services/AutoscalerService?wsdl
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>> correction,
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>> https://
> <stratos-server>:<port>/services/AutoScalerService?wsdl
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>> On Sat, Sep 27, 2014 at 1:18 AM, Rajkumar Rajaratnam
> >>>>> >>>>>>>>>>>>>> <ra...@wso2.com> wrote:
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>> On Sat, Sep 27, 2014 at 1:15 AM, Sajith Kariyawasam
> >>>>> >>>>>>>>>>>>>>> <sa...@wso2.com> wrote:
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>> On Sat, Sep 27, 2014 at 1:12 AM, Rajkumar Rajaratnam
> >>>>> >>>>>>>>>>>>>>>> <ra...@wso2.com> wrote:
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>> Hi,
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>> As you know docker-integration branch is merged
> into
> >>>>> >>>>>>>>>>>>>>>>> master
> >>>>> >>>>>>>>>>>>>>>>> branch. I am doing test on the master branch now. I
> >>>>> >>>>>>>>>>>>>>>>> will keep post in this
> >>>>> >>>>>>>>>>>>>>>>> thread the status of the testing.
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>> I got the following exception when I register a
> >>>>> >>>>>>>>>>>>>>>>> kubernetes
> >>>>> >>>>>>>>>>>>>>>>> group via rest API. It is not happening in the
> >>>>> >>>>>>>>>>>>>>>>> docker-integration branch.
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>> Its not happening in docker-integration branch or
> >>>>> >>>>>>>>>>>>>>>> master
> >>>>> >>>>>>>>>>>>>>>> branch? Could you post the REST call you used?
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>> Now I am using master branch. It is happening in the
> >>>>> >>>>>>>>>>>>>>> master
> >>>>> >>>>>>>>>>>>>>> branch. Earlier I tested docker branch. It was not
> >>>>> >>>>>>>>>>>>>>> giving this error.
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>> This is the curl command
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>> curl -X POST -H "Content-Type: application/json" -d
> >>>>> >>>>>>>>>>>>>>> @"new-kub-register.json" -k  -u admin:admin
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>> "
> https://127.0.0.1:9443/stratos/admin/kubernetes/deploy/group"
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>> This is the result
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>> {"Error":{ "errorCode": " 400", "errorMessage": "
> >>>>> >>>>>>>>>>>>>>> argument
> >>>>> >>>>>>>>>>>>>>> type mismatch"}}
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>> TID: [0] [STRATOS] [2014-09-27 01:04:09,273] ERROR
> >>>>> >>>>>>>>>>>>>>>>>
> {org.apache.axis2.rpc.receivers.RPCMessageReceiver} -
> >>>>> >>>>>>>>>>>>>>>>> argument type
> >>>>> >>>>>>>>>>>>>>>>> mismatch
> >>>>> >>>>>>>>>>>>>>>>> {org.apache.axis2.rpc.receivers.RPCMessageReceiver}
> >>>>> >>>>>>>>>>>>>>>>> java.lang.IllegalArgumentException: argument type
> >>>>> >>>>>>>>>>>>>>>>> mismatch
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>> sun.reflect.NativeMethodAccessorImpl.invoke0(Native
> >>>>> >>>>>>>>>>>>>>>>> Method)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:39)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:25)
> >>>>> >>>>>>>>>>>>>>>>> at java.lang.reflect.Method.invoke(Method.java:597)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.databinding.utils.BeanUtil.deserialize(BeanUtil.java:477)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.databinding.utils.BeanUtil.processObject(BeanUtil.java:827)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.databinding.utils.BeanUtil.ProcessElement(BeanUtil.java:746)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.databinding.utils.BeanUtil.deserialize(BeanUtil.java:655)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.rpc.receivers.RPCUtil.processRequest(RPCUtil.java:153)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.rpc.receivers.RPCUtil.invokeServiceClass(RPCUtil.java:206)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.rpc.receivers.RPCMessageReceiver.invokeBusinessLogic(RPCMessageReceiver.java:117)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.receivers.AbstractInOutMessageReceiver.invokeBusinessLogic(AbstractInOutMessageReceiver.java:40)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.receivers.AbstractMessageReceiver.receive(AbstractMessageReceiver.java:110)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.engine.AxisEngine.receive(AxisEngine.java:180)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.transport.http.HTTPTransportUtils.processHTTPPostRequest(HTTPTransportUtils.java:172)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.transport.http.AxisServlet.doPost(AxisServlet.java:146)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.core.transports.CarbonServlet.doPost(CarbonServlet.java:231)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> javax.servlet.http.HttpServlet.service(HttpServlet.java:755)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> javax.servlet.http.HttpServlet.service(HttpServlet.java:848)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.eclipse.equinox.http.servlet.internal.ServletRegistration.service(ServletRegistration.java:61)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.eclipse.equinox.http.servlet.internal.ProxyServlet.processAlias(ProxyServlet.java:128)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.eclipse.equinox.http.servlet.internal.ProxyServlet.service(ProxyServlet.java:68)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> javax.servlet.http.HttpServlet.service(HttpServlet.java:848)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.servlet.DelegationServlet.service(DelegationServlet.java:68)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.ApplicationFilterChain.internalDoFilter(ApplicationFilterChain.java:305)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.ApplicationFilterChain.doFilter(ApplicationFilterChain.java:210)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.filter.CharacterSetFilter.doFilter(CharacterSetFilter.java:61)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.ApplicationFilterChain.internalDoFilter(ApplicationFilterChain.java:243)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.ApplicationFilterChain.doFilter(ApplicationFilterChain.java:210)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardWrapperValve.invoke(StandardWrapperValve.java:222)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardContextValve.invoke(StandardContextValve.java:123)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.authenticator.AuthenticatorBase.invoke(AuthenticatorBase.java:472)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardHostValve.invoke(StandardHostValve.java:171)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.valves.ErrorReportValve.invoke(ErrorReportValve.java:99)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CompositeValve.continueInvocation(CompositeValve.java:178)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonTomcatValve$1.invoke(CarbonTomcatValve.java:47)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.webapp.mgt.TenantLazyLoaderValve.invoke(TenantLazyLoaderValve.java:56)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.TomcatValveContainer.invokeValves(TomcatValveContainer.java:47)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CompositeValve.invoke(CompositeValve.java:141)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonStuckThreadDetectionValve.invoke(CarbonStuckThreadDetectionValve.java:156)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.valves.AccessLogValve.invoke(AccessLogValve.java:936)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonContextCreatorValve.invoke(CarbonContextCreatorValve.java:52)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardEngineValve.invoke(StandardEngineValve.java:118)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.connector.CoyoteAdapter.service(CoyoteAdapter.java:407)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.coyote.http11.AbstractHttp11Processor.process(AbstractHttp11Processor.java:1004)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.coyote.AbstractProtocol$AbstractConnectionHandler.process(AbstractProtocol.java:589)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.tomcat.util.net.NioEndpoint$SocketProcessor.run(NioEndpoint.java:1653)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:885)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:907)
> >>>>> >>>>>>>>>>>>>>>>> at java.lang.Thread.run(Thread.java:619)
> >>>>> >>>>>>>>>>>>>>>>> TID: [0] [STRATOS] [2014-09-27 01:04:09,336] ERROR
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> {org.apache.stratos.rest.endpoint.services.ServiceUtils} -  argument type
> >>>>> >>>>>>>>>>>>>>>>> mismatch
> >>>>> >>>>>>>>>>>>>>>>>
> {org.apache.stratos.rest.endpoint.services.ServiceUtils}
> >>>>> >>>>>>>>>>>>>>>>> org.apache.axis2.AxisFault: argument type mismatch
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.util.Utils.getInboundFaultFromMessageContext(Utils.java:531)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.description.OutInAxisOperationClient.handleResponse(OutInAxisOperation.java:370)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.description.OutInAxisOperationClient.send(OutInAxisOperation.java:445)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.description.OutInAxisOperationClient.executeImpl(OutInAxisOperation.java:225)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.client.OperationClient.execute(OperationClient.java:149)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.autoscaler.stub.AutoScalerServiceStub.addKubernetesGroup(AutoScalerServiceStub.java:8006)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.manager.client.AutoscalerServiceClient.deployKubernetesGroup(AutoscalerServiceClient.java:216)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.rest.endpoint.services.ServiceUtils.deployKubernetesGroup(ServiceUtils.java:1356)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.rest.endpoint.services.StratosAdmin.deployKubernetesGroup(StratosAdmin.java:1207)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>> sun.reflect.NativeMethodAccessorImpl.invoke0(Native
> >>>>> >>>>>>>>>>>>>>>>> Method)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:39)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:25)
> >>>>> >>>>>>>>>>>>>>>>> at java.lang.reflect.Method.invoke(Method.java:597)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.service.invoker.AbstractInvoker.performInvocation(AbstractInvoker.java:180)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.service.invoker.AbstractInvoker.invoke(AbstractInvoker.java:96)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.jaxrs.JAXRSInvoker.invoke(JAXRSInvoker.java:194)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.jaxrs.JAXRSInvoker.invoke(JAXRSInvoker.java:100)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.interceptor.ServiceInvokerInterceptor$1.run(ServiceInvokerInterceptor.java:57)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.interceptor.ServiceInvokerInterceptor.handleMessage(ServiceInvokerInterceptor.java:93)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:271)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.ChainInitiationObserver.onMessage(ChainInitiationObserver.java:121)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.http.AbstractHTTPDestination.invoke(AbstractHTTPDestination.java:239)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.ServletController.invokeDestination(ServletController.java:223)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.ServletController.invoke(ServletController.java:203)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.ServletController.invoke(ServletController.java:137)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.CXFNonSpringServlet.invoke(CXFNonSpringServlet.java:159)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.AbstractHTTPServlet.handleRequest(AbstractHTTPServlet.java:286)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.AbstractHTTPServlet.doPost(AbstractHTTPServlet.java:206)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> javax.servlet.http.HttpServlet.service(HttpServlet.java:755)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.AbstractHTTPServlet.service(AbstractHTTPServlet.java:262)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.ApplicationFilterChain.internalDoFilter(ApplicationFilterChain.java:305)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.ApplicationFilterChain.doFilter(ApplicationFilterChain.java:210)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardWrapperValve.invoke(StandardWrapperValve.java:222)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardContextValve.invoke(StandardContextValve.java:123)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.authenticator.AuthenticatorBase.invoke(AuthenticatorBase.java:472)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardHostValve.invoke(StandardHostValve.java:171)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.valves.ErrorReportValve.invoke(ErrorReportValve.java:99)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CompositeValve.continueInvocation(CompositeValve.java:178)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonTomcatValve$1.invoke(CarbonTomcatValve.java:47)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.webapp.mgt.TenantLazyLoaderValve.invoke(TenantLazyLoaderValve.java:56)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.TomcatValveContainer.invokeValves(TomcatValveContainer.java:47)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CompositeValve.invoke(CompositeValve.java:141)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonStuckThreadDetectionValve.invoke(CarbonStuckThreadDetectionValve.java:156)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.valves.AccessLogValve.invoke(AccessLogValve.java:936)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonContextCreatorValve.invoke(CarbonContextCreatorValve.java:52)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardEngineValve.invoke(StandardEngineValve.java:118)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.connector.CoyoteAdapter.service(CoyoteAdapter.java:407)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.coyote.http11.AbstractHttp11Processor.process(AbstractHttp11Processor.java:1004)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.coyote.AbstractProtocol$AbstractConnectionHandler.process(AbstractProtocol.java:589)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.tomcat.util.net.NioEndpoint$SocketProcessor.run(NioEndpoint.java:1653)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:885)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:907)
> >>>>> >>>>>>>>>>>>>>>>> at java.lang.Thread.run(Thread.java:619)
> >>>>> >>>>>>>>>>>>>>>>> TID: [0] [STRATOS] [2014-09-27 01:04:09,339] ERROR
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> {org.apache.stratos.rest.endpoint.handlers.CustomExceptionMapper} -
> >>>>> >>>>>>>>>>>>>>>>> argument type mismatch
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> {org.apache.stratos.rest.endpoint.handlers.CustomExceptionMapper}
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.rest.endpoint.exception.RestAPIException: argument type
> >>>>> >>>>>>>>>>>>>>>>> mismatch
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.rest.endpoint.services.ServiceUtils.deployKubernetesGroup(ServiceUtils.java:1359)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.rest.endpoint.services.StratosAdmin.deployKubernetesGroup(StratosAdmin.java:1207)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>> sun.reflect.NativeMethodAccessorImpl.invoke0(Native
> >>>>> >>>>>>>>>>>>>>>>> Method)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:39)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:25)
> >>>>> >>>>>>>>>>>>>>>>> at java.lang.reflect.Method.invoke(Method.java:597)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.service.invoker.AbstractInvoker.performInvocation(AbstractInvoker.java:180)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.service.invoker.AbstractInvoker.invoke(AbstractInvoker.java:96)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.jaxrs.JAXRSInvoker.invoke(JAXRSInvoker.java:194)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.jaxrs.JAXRSInvoker.invoke(JAXRSInvoker.java:100)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.interceptor.ServiceInvokerInterceptor$1.run(ServiceInvokerInterceptor.java:57)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.interceptor.ServiceInvokerInterceptor.handleMessage(ServiceInvokerInterceptor.java:93)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:271)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.ChainInitiationObserver.onMessage(ChainInitiationObserver.java:121)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.http.AbstractHTTPDestination.invoke(AbstractHTTPDestination.java:239)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.ServletController.invokeDestination(ServletController.java:223)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.ServletController.invoke(ServletController.java:203)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.ServletController.invoke(ServletController.java:137)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.CXFNonSpringServlet.invoke(CXFNonSpringServlet.java:159)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.AbstractHTTPServlet.handleRequest(AbstractHTTPServlet.java:286)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.AbstractHTTPServlet.doPost(AbstractHTTPServlet.java:206)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> javax.servlet.http.HttpServlet.service(HttpServlet.java:755)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.cxf.transport.servlet.AbstractHTTPServlet.service(AbstractHTTPServlet.java:262)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.ApplicationFilterChain.internalDoFilter(ApplicationFilterChain.java:305)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.ApplicationFilterChain.doFilter(ApplicationFilterChain.java:210)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardWrapperValve.invoke(StandardWrapperValve.java:222)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardContextValve.invoke(StandardContextValve.java:123)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.authenticator.AuthenticatorBase.invoke(AuthenticatorBase.java:472)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardHostValve.invoke(StandardHostValve.java:171)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.valves.ErrorReportValve.invoke(ErrorReportValve.java:99)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CompositeValve.continueInvocation(CompositeValve.java:178)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonTomcatValve$1.invoke(CarbonTomcatValve.java:47)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.webapp.mgt.TenantLazyLoaderValve.invoke(TenantLazyLoaderValve.java:56)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.TomcatValveContainer.invokeValves(TomcatValveContainer.java:47)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CompositeValve.invoke(CompositeValve.java:141)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonStuckThreadDetectionValve.invoke(CarbonStuckThreadDetectionValve.java:156)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.valves.AccessLogValve.invoke(AccessLogValve.java:936)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.wso2.carbon.tomcat.ext.valves.CarbonContextCreatorValve.invoke(CarbonContextCreatorValve.java:52)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.core.StandardEngineValve.invoke(StandardEngineValve.java:118)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.catalina.connector.CoyoteAdapter.service(CoyoteAdapter.java:407)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.coyote.http11.AbstractHttp11Processor.process(AbstractHttp11Processor.java:1004)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.coyote.AbstractProtocol$AbstractConnectionHandler.process(AbstractProtocol.java:589)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.tomcat.util.net.NioEndpoint$SocketProcessor.run(NioEndpoint.java:1653)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:885)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:907)
> >>>>> >>>>>>>>>>>>>>>>> at java.lang.Thread.run(Thread.java:619)
> >>>>> >>>>>>>>>>>>>>>>> Caused by: org.apache.axis2.AxisFault: argument
> type
> >>>>> >>>>>>>>>>>>>>>>> mismatch
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.util.Utils.getInboundFaultFromMessageContext(Utils.java:531)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.description.OutInAxisOperationClient.handleResponse(OutInAxisOperation.java:370)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.description.OutInAxisOperationClient.send(OutInAxisOperation.java:445)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.description.OutInAxisOperationClient.executeImpl(OutInAxisOperation.java:225)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.axis2.client.OperationClient.execute(OperationClient.java:149)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.autoscaler.stub.AutoScalerServiceStub.addKubernetesGroup(AutoScalerServiceStub.java:8006)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.manager.client.AutoscalerServiceClient.deployKubernetesGroup(AutoscalerServiceClient.java:216)
> >>>>> >>>>>>>>>>>>>>>>> at
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> org.apache.stratos.rest.endpoint.services.ServiceUtils.deployKubernetesGroup(ServiceUtils.java:1356)
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>> Any idea?
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>> Thanks
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>> --
> >>>>> >>>>>>>>>>>>>>>>> Rajkumar Rajaratnam
> >>>>> >>>>>>>>>>>>>>>>> Software Engineer | WSO2, Inc.
> >>>>> >>>>>>>>>>>>>>>>> Mobile +94777568639 | +94783498120
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>> --
> >>>>> >>>>>>>>>>>>>>>> Sajith Kariyawasam
> >>>>> >>>>>>>>>>>>>>>> Committer and PMC member, Apache Stratos,
> >>>>> >>>>>>>>>>>>>>>> WSO2 Inc., http://wso2.com
> >>>>> >>>>>>>>>>>>>>>> AMIE (SL)
> >>>>> >>>>>>>>>>>>>>>> Mobile: +94772269575
> >>>>> >>>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>> --
> >>>>> >>>>>>>>>>>>>>> Rajkumar Rajaratnam
> >>>>> >>>>>>>>>>>>>>> Software Engineer | WSO2, Inc.
> >>>>> >>>>>>>>>>>>>>> Mobile +94777568639 | +94783498120
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>> --
> >>>>> >>>>>>>>>>>>>> Sajith Kariyawasam
> >>>>> >>>>>>>>>>>>>> Committer and PMC member, Apache Stratos,
> >>>>> >>>>>>>>>>>>>> WSO2 Inc., http://wso2.com
> >>>>> >>>>>>>>>>>>>> AMIE (SL)
> >>>>> >>>>>>>>>>>>>> Mobile: +94772269575
> >>>>> >>>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>> --
> >>>>> >>>>>>>>>>>>> Sajith Kariyawasam
> >>>>> >>>>>>>>>>>>> Committer and PMC member, Apache Stratos,
> >>>>> >>>>>>>>>>>>> WSO2 Inc., http://wso2.com
> >>>>> >>>>>>>>>>>>> AMIE (SL)
> >>>>> >>>>>>>>>>>>> Mobile: +94772269575
> >>>>> >>>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>
> >>>>> >>>>>>>>>>>>
> >>>>> >>>>>>>>>>>> --
> >>>>> >>>>>>>>>>>> Rajkumar Rajaratnam
> >>>>> >>>>>>>>>>>> Software Engineer | WSO2, Inc.
> >>>>> >>>>>>>>>>>> Mobile +94777568639 | +94783498120
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>> --
> >>>>> >>>>>>>>>>> Regards,
> >>>>> >>>>>>>>>>> Manula Chathurika Thantriwatte
> >>>>> >>>>>>>>>>> Software Engineer
> >>>>> >>>>>>>>>>> WSO2 Inc. : http://wso2.com
> >>>>> >>>>>>>>>>> lean . enterprise . middleware
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>> email : manulac@wso2.com / manula@apache.org
> >>>>> >>>>>>>>>>> phone : +94 772492511
> >>>>> >>>>>>>>>>> blog : http://manulachathurika.blogspot.com/
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>>
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>>
> >>>>> >>>>>>>>>> --
> >>>>> >>>>>>>>>> Rajkumar Rajaratnam
> >>>>> >>>>>>>>>> Software Engineer | WSO2, Inc.
> >>>>> >>>>>>>>>> Mobile +94777568639 | +94783498120
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>> --
> >>>>> >>>>>>>>> Best Regards,
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>> Gayan Gunarathne
> >>>>> >>>>>>>>> Technical Lead
> >>>>> >>>>>>>>> WSO2 Inc. (http://wso2.com)
> >>>>> >>>>>>>>> email  : gayang@wso2.com  | mobile : +94 766819985
> >>>>> >>>>>>>>>
> >>>>> >>>>>>>>
> >>>>> >>>>>>>>
> >>>>> >>>>>>>>
> >>>>> >>>>>>>>
> >>>>> >>>>>>>> --
> >>>>> >>>>>>>> Rajkumar Rajaratnam
> >>>>> >>>>>>>> Software Engineer | WSO2, Inc.
> >>>>> >>>>>>>> Mobile +94777568639 | +94783498120
> >>>>> >>>>>>>
> >>>>> >>>>>>>
> >>>>> >>>>>>>
> >>>>> >>>>>>>
> >>>>> >>>>>>> --
> >>>>> >>>>>>> Rajkumar Rajaratnam
> >>>>> >>>>>>> Software Engineer | WSO2, Inc.
> >>>>> >>>>>>> Mobile +94777568639 | +94783498120
> >>>>> >>>>>>
> >>>>> >>>>>>
> >>>>> >>>>>>
> >>>>> >>>>>>
> >>>>> >>>>>> --
> >>>>> >>>>>> Best Regards,
> >>>>> >>>>>>
> >>>>> >>>>>> Gayan Gunarathne
> >>>>> >>>>>> Technical Lead
> >>>>> >>>>>> WSO2 Inc. (http://wso2.com)
> >>>>> >>>>>> email  : gayang@wso2.com  | mobile : +94 766819985
> >>>>> >>>>>>
> >>>>> >>>>>
> >>>>> >>>>>
> >>>>> >>>>>
> >>>>> >>>>>
> >>>>> >>>>> --
> >>>>> >>>>> Rajkumar Rajaratnam
> >>>>> >>>>> Software Engineer | WSO2, Inc.
> >>>>> >>>>> Mobile +94777568639 | +94783498120
> >>>>> >>>>
> >>>>> >>>>
> >>>>> >>>>
> >>>>> >>>>
> >>>>> >>>> --
> >>>>> >>>> Best Regards,
> >>>>> >>>>
> >>>>> >>>> Gayan Gunarathne
> >>>>> >>>> Technical Lead
> >>>>> >>>> WSO2 Inc. (http://wso2.com)
> >>>>> >>>> email  : gayang@wso2.com  | mobile : +94 766819985
> >>>>> >>>>
> >>>>> >>>
> >>>>> >>>
> >>>>> >>>
> >>>>> >>>
> >>>>> >>> --
> >>>>> >>> Rajkumar Rajaratnam
> >>>>> >>> Software Engineer | WSO2, Inc.
> >>>>> >>> Mobile +94777568639 | +94783498120
> >>>>> >>
> >>>>> >>
> >>>>> >>
> >>>>> >>
> >>>>> >> --
> >>>>> >> Sajith Kariyawasam
> >>>>> >> Committer and PMC member, Apache Stratos,
> >>>>> >> WSO2 Inc., http://wso2.com
> >>>>> >> AMIE (SL)
> >>>>> >> Mobile: +94772269575
> >>>>> >>
> >>>>> >
> >>>>> >
> >>>>> >
> >>>>> > --
> >>>>> > Rajkumar Rajaratnam
> >>>>> > Software Engineer | WSO2, Inc.
> >>>>> > Mobile +94777568639 | +94783498120
> >>>>>
> >>>>>
> >>>>>
> >>>>> --
> >>>>> Akila Ravihansa Perera
> >>>>> Software Engineer, WSO2
> >>>>>
> >>>>> Blog: http://ravihansa3000.blogspot.com
> >>>>
> >>>>
> >>>>
> >>>>
> >>>> --
> >>>> Rajkumar Rajaratnam
> >>>> Software Engineer | WSO2, Inc.
> >>>> Mobile +94777568639 | +94783498120
> >>>
> >>>
> >>>
> >>>
> >>> --
> >>> Best Regards,
> >>>
> >>> Gayan Gunarathne
> >>> Technical Lead
> >>> WSO2 Inc. (http://wso2.com)
> >>> email  : gayang@wso2.com  | mobile : +94 766819985
> >>>
> >>
> >>
> >>
> >>
> >> --
> >> Sajith Kariyawasam
> >> Committer and PMC member, Apache Stratos,
> >> WSO2 Inc., http://wso2.com
> >> AMIE (SL)
> >> Mobile: +94772269575
> >>
> >
> >
> >
> > --
> > Rajkumar Rajaratnam
> > Software Engineer | WSO2, Inc.
> > Mobile +94777568639 | +94783498120
>
>
>
> --
> Akila Ravihansa Perera
> Software Engineer, WSO2
>
> Blog: http://ravihansa3000.blogspot.com
>



-- 
Rajkumar Rajaratnam
Software Engineer | WSO2, Inc.
Mobile +94777568639 | +94783498120