You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by sm...@apache.org on 2015/05/03 14:40:00 UTC

[20/51] [partial] airavata-php-gateway git commit: removing vendor files

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/GelfHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/GelfHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/GelfHandler.php
deleted file mode 100644
index 790f636..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/GelfHandler.php
+++ /dev/null
@@ -1,72 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Gelf\IMessagePublisher;
-use Gelf\PublisherInterface;
-use InvalidArgumentException;
-use Monolog\Logger;
-use Monolog\Formatter\GelfMessageFormatter;
-
-/**
- * Handler to send messages to a Graylog2 (http://www.graylog2.org) server
- *
- * @author Matt Lehner <ml...@gmail.com>
- * @author Benjamin Zikarsky <be...@zikarsky.de>
- */
-class GelfHandler extends AbstractProcessingHandler
-{
-    /**
-     * @var Publisher the publisher object that sends the message to the server
-     */
-    protected $publisher;
-
-    /**
-     * @param PublisherInterface|IMessagePublisher $publisher a publisher object
-     * @param integer                              $level     The minimum logging level at which this handler will be triggered
-     * @param boolean                              $bubble    Whether the messages that are handled can bubble up the stack or not
-     */
-    public function __construct($publisher, $level = Logger::DEBUG, $bubble = true)
-    {
-        parent::__construct($level, $bubble);
-
-        if (!$publisher instanceof IMessagePublisher && !$publisher instanceof PublisherInterface) {
-            throw new InvalidArgumentException("Invalid publisher, expected a Gelf\IMessagePublisher or Gelf\PublisherInterface instance");
-        }
-
-        $this->publisher = $publisher;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function close()
-    {
-        $this->publisher = null;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        $this->publisher->publish($record['formatted']);
-    }
-
-    /**
-     * {@inheritDoc}
-     */
-    protected function getDefaultFormatter()
-    {
-        return new GelfMessageFormatter();
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/GroupHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/GroupHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/GroupHandler.php
deleted file mode 100644
index 99384d3..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/GroupHandler.php
+++ /dev/null
@@ -1,80 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-/**
- * Forwards records to multiple handlers
- *
- * @author Lenar Lõhmus <le...@city.ee>
- */
-class GroupHandler extends AbstractHandler
-{
-    protected $handlers;
-
-    /**
-     * @param array   $handlers Array of Handlers.
-     * @param Boolean $bubble   Whether the messages that are handled can bubble up the stack or not
-     */
-    public function __construct(array $handlers, $bubble = true)
-    {
-        foreach ($handlers as $handler) {
-            if (!$handler instanceof HandlerInterface) {
-                throw new \InvalidArgumentException('The first argument of the GroupHandler must be an array of HandlerInterface instances.');
-            }
-        }
-
-        $this->handlers = $handlers;
-        $this->bubble = $bubble;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function isHandling(array $record)
-    {
-        foreach ($this->handlers as $handler) {
-            if ($handler->isHandling($record)) {
-                return true;
-            }
-        }
-
-        return false;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function handle(array $record)
-    {
-        if ($this->processors) {
-            foreach ($this->processors as $processor) {
-                $record = call_user_func($processor, $record);
-            }
-        }
-
-        foreach ($this->handlers as $handler) {
-            $handler->handle($record);
-        }
-
-        return false === $this->bubble;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function handleBatch(array $records)
-    {
-        foreach ($this->handlers as $handler) {
-            $handler->handleBatch($records);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/HandlerInterface.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/HandlerInterface.php b/vendor/monolog/monolog/src/Monolog/Handler/HandlerInterface.php
deleted file mode 100644
index d920c4b..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/HandlerInterface.php
+++ /dev/null
@@ -1,90 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Formatter\FormatterInterface;
-
-/**
- * Interface that all Monolog Handlers must implement
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-interface HandlerInterface
-{
-    /**
-     * Checks whether the given record will be handled by this handler.
-     *
-     * This is mostly done for performance reasons, to avoid calling processors for nothing.
-     *
-     * Handlers should still check the record levels within handle(), returning false in isHandling()
-     * is no guarantee that handle() will not be called, and isHandling() might not be called
-     * for a given record.
-     *
-     * @param array $record Partial log record containing only a level key
-     *
-     * @return Boolean
-     */
-    public function isHandling(array $record);
-
-    /**
-     * Handles a record.
-     *
-     * All records may be passed to this method, and the handler should discard
-     * those that it does not want to handle.
-     *
-     * The return value of this function controls the bubbling process of the handler stack.
-     * Unless the bubbling is interrupted (by returning true), the Logger class will keep on
-     * calling further handlers in the stack with a given log record.
-     *
-     * @param  array   $record The record to handle
-     * @return Boolean true means that this handler handled the record, and that bubbling is not permitted.
-     *                        false means the record was either not processed or that this handler allows bubbling.
-     */
-    public function handle(array $record);
-
-    /**
-     * Handles a set of records at once.
-     *
-     * @param array $records The records to handle (an array of record arrays)
-     */
-    public function handleBatch(array $records);
-
-    /**
-     * Adds a processor in the stack.
-     *
-     * @param  callable $callback
-     * @return self
-     */
-    public function pushProcessor($callback);
-
-    /**
-     * Removes the processor on top of the stack and returns it.
-     *
-     * @return callable
-     */
-    public function popProcessor();
-
-    /**
-     * Sets the formatter.
-     *
-     * @param  FormatterInterface $formatter
-     * @return self
-     */
-    public function setFormatter(FormatterInterface $formatter);
-
-    /**
-     * Gets the formatter.
-     *
-     * @return FormatterInterface
-     */
-    public function getFormatter();
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/HipChatHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/HipChatHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/HipChatHandler.php
deleted file mode 100644
index 185e86e..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/HipChatHandler.php
+++ /dev/null
@@ -1,306 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * Sends notifications through the hipchat api to a hipchat room
- *
- * Notes:
- * API token - HipChat API token
- * Room      - HipChat Room Id or name, where messages are sent
- * Name      - Name used to send the message (from)
- * notify    - Should the message trigger a notification in the clients
- *
- * @author Rafael Dohms <ra...@doh.ms>
- * @see    https://www.hipchat.com/docs/api
- */
-class HipChatHandler extends SocketHandler
-{
-    /**
-     * The maximum allowed length for the name used in the "from" field.
-     */
-    const MAXIMUM_NAME_LENGTH = 15;
-
-    /**
-     * The maximum allowed length for the message.
-     */
-    const MAXIMUM_MESSAGE_LENGTH = 9500;
-
-    /**
-     * @var string
-     */
-    private $token;
-
-    /**
-     * @var string
-     */
-    private $room;
-
-    /**
-     * @var string
-     */
-    private $name;
-
-    /**
-     * @var bool
-     */
-    private $notify;
-
-    /**
-     * @var string
-     */
-    private $format;
-
-    /**
-     * @var string
-     */
-    private $host;
-
-    /**
-     * @param string  $token  HipChat API Token
-     * @param string  $room   The room that should be alerted of the message (Id or Name)
-     * @param string  $name   Name used in the "from" field
-     * @param bool    $notify Trigger a notification in clients or not
-     * @param int     $level  The minimum logging level at which this handler will be triggered
-     * @param bool    $bubble Whether the messages that are handled can bubble up the stack or not
-     * @param bool    $useSSL Whether to connect via SSL.
-     * @param string  $format The format of the messages (default to text, can be set to html if you have html in the messages)
-     * @param string  $host   The HipChat server hostname.
-     */
-    public function __construct($token, $room, $name = 'Monolog', $notify = false, $level = Logger::CRITICAL, $bubble = true, $useSSL = true, $format = 'text', $host = 'api.hipchat.com')
-    {
-        if (!$this->validateStringLength($name, static::MAXIMUM_NAME_LENGTH)) {
-            throw new \InvalidArgumentException('The supplied name is too long. HipChat\'s v1 API supports names up to 15 UTF-8 characters.');
-        }
-
-        $connectionString = $useSSL ? 'ssl://'.$host.':443' : $host.':80';
-        parent::__construct($connectionString, $level, $bubble);
-
-        $this->token = $token;
-        $this->name = $name;
-        $this->notify = $notify;
-        $this->room = $room;
-        $this->format = $format;
-        $this->host = $host;
-    }
-
-    /**
-     * {@inheritdoc}
-     *
-     * @param  array  $record
-     * @return string
-     */
-    protected function generateDataStream($record)
-    {
-        $content = $this->buildContent($record);
-
-        return $this->buildHeader($content) . $content;
-    }
-
-    /**
-     * Builds the body of API call
-     *
-     * @param  array  $record
-     * @return string
-     */
-    private function buildContent($record)
-    {
-        $dataArray = array(
-            'from' => $this->name,
-            'room_id' => $this->room,
-            'notify' => $this->notify,
-            'message' => $record['formatted'],
-            'message_format' => $this->format,
-            'color' => $this->getAlertColor($record['level']),
-        );
-
-        return http_build_query($dataArray);
-    }
-
-    /**
-     * Builds the header of the API Call
-     *
-     * @param  string $content
-     * @return string
-     */
-    private function buildHeader($content)
-    {
-        $header = "POST /v1/rooms/message?format=json&auth_token=".$this->token." HTTP/1.1\r\n";
-        $header .= "Host: {$this->host}\r\n";
-        $header .= "Content-Type: application/x-www-form-urlencoded\r\n";
-        $header .= "Content-Length: " . strlen($content) . "\r\n";
-        $header .= "\r\n";
-
-        return $header;
-    }
-
-    /**
-     * Assigns a color to each level of log records.
-     *
-     * @param  integer $level
-     * @return string
-     */
-    protected function getAlertColor($level)
-    {
-        switch (true) {
-            case $level >= Logger::ERROR:
-                return 'red';
-            case $level >= Logger::WARNING:
-                return 'yellow';
-            case $level >= Logger::INFO:
-                return 'green';
-            case $level == Logger::DEBUG:
-                return 'gray';
-            default:
-                return 'yellow';
-        }
-    }
-
-    /**
-     * {@inheritdoc}
-     *
-     * @param array $record
-     */
-    protected function write(array $record)
-    {
-        parent::write($record);
-        $this->closeSocket();
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function handleBatch(array $records)
-    {
-        if (count($records) == 0) {
-            return true;
-        }
-
-        $batchRecords = $this->combineRecords($records);
-
-        $handled = false;
-        foreach ($batchRecords as $batchRecord) {
-            if ($this->isHandling($batchRecord)) {
-                $this->write($batchRecord);
-                $handled = true;
-            }
-        }
-
-        if (!$handled) {
-            return false;
-        }
-
-        return false === $this->bubble;
-    }
-
-    /**
-     * Combines multiple records into one. Error level of the combined record
-     * will be the highest level from the given records. Datetime will be taken
-     * from the first record.
-     *
-     * @param $records
-     * @return array
-     */
-    private function combineRecords($records)
-    {
-        $batchRecord = null;
-        $batchRecords = array();
-        $messages = array();
-        $formattedMessages = array();
-        $level = 0;
-        $levelName = null;
-        $datetime = null;
-
-        foreach ($records as $record) {
-            $record = $this->processRecord($record);
-
-            if ($record['level'] > $level) {
-                $level = $record['level'];
-                $levelName = $record['level_name'];
-            }
-
-            if (null === $datetime) {
-                $datetime = $record['datetime'];
-            }
-
-            $messages[] = $record['message'];
-            $messageStr = implode(PHP_EOL, $messages);
-            $formattedMessages[] = $this->getFormatter()->format($record);
-            $formattedMessageStr = implode('', $formattedMessages);
-
-            $batchRecord = array(
-                'message'   => $messageStr,
-                'formatted' => $formattedMessageStr,
-                'context'   => array(),
-                'extra'     => array(),
-            );
-
-            if (!$this->validateStringLength($batchRecord['formatted'], static::MAXIMUM_MESSAGE_LENGTH)) {
-                // Pop the last message and implode the remaining messages
-                $lastMessage = array_pop($messages);
-                $lastFormattedMessage = array_pop($formattedMessages);
-                $batchRecord['message'] = implode(PHP_EOL, $messages);
-                $batchRecord['formatted'] = implode('', $formattedMessages);
-
-                $batchRecords[] = $batchRecord;
-                $messages = array($lastMessage);
-                $formattedMessages = array($lastFormattedMessage);
-
-                $batchRecord = null;
-            }
-        }
-
-        if (null !== $batchRecord) {
-            $batchRecords[] = $batchRecord;
-        }
-
-        // Set the max level and datetime for all records
-        foreach ($batchRecords as &$batchRecord) {
-            $batchRecord = array_merge(
-                $batchRecord,
-                array(
-                    'level'      => $level,
-                    'level_name' => $levelName,
-                    'datetime'   => $datetime
-                )
-            );
-        }
-
-        return $batchRecords;
-    }
-
-    /**
-     * Validates the length of a string.
-     *
-     * If the `mb_strlen()` function is available, it will use that, as HipChat
-     * allows UTF-8 characters. Otherwise, it will fall back to `strlen()`.
-     *
-     * Note that this might cause false failures in the specific case of using
-     * a valid name with less than 16 characters, but 16 or more bytes, on a
-     * system where `mb_strlen()` is unavailable.
-     *
-     * @param string $str
-     * @param int    $length
-     *
-     * @return bool
-     */
-    private function validateStringLength($str, $length)
-    {
-        if (function_exists('mb_strlen')) {
-            return (mb_strlen($str) <= $length);
-        }
-
-        return (strlen($str) <= $length);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/LogEntriesHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/LogEntriesHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/LogEntriesHandler.php
deleted file mode 100644
index bd56230..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/LogEntriesHandler.php
+++ /dev/null
@@ -1,55 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * @author Robert Kaufmann III <ro...@rok3.me>
- */
-class LogEntriesHandler extends SocketHandler
-{
-    /**
-     * @var string
-     */
-    protected $logToken;
-
-    /**
-     * @param string  $token  Log token supplied by LogEntries
-     * @param boolean $useSSL Whether or not SSL encryption should be used.
-     * @param int     $level  The minimum logging level to trigger this handler
-     * @param boolean $bubble Whether or not messages that are handled should bubble up the stack.
-     *
-     * @throws MissingExtensionException If SSL encryption is set to true and OpenSSL is missing
-     */
-    public function __construct($token, $useSSL = true, $level = Logger::DEBUG, $bubble = true)
-    {
-        if ($useSSL && !extension_loaded('openssl')) {
-            throw new MissingExtensionException('The OpenSSL PHP plugin is required to use SSL encrypted connection for LogEntriesHandler');
-        }
-
-        $endpoint = $useSSL ? 'ssl://data.logentries.com:443' : 'data.logentries.com:80';
-        parent::__construct($endpoint, $level, $bubble);
-        $this->logToken = $token;
-    }
-
-    /**
-     * {@inheritdoc}
-     *
-     * @param  array  $record
-     * @return string
-     */
-    protected function generateDataStream($record)
-    {
-        return $this->logToken . ' ' . $record['formatted'];
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/LogglyHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/LogglyHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/LogglyHandler.php
deleted file mode 100644
index efd94d3..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/LogglyHandler.php
+++ /dev/null
@@ -1,98 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-use Monolog\Formatter\LogglyFormatter;
-
-/**
- * Sends errors to Loggly.
- *
- * @author Przemek Sobstel <pr...@sobstel.org>
- * @author Adam Pancutt <ad...@pancutt.com>
- */
-class LogglyHandler extends AbstractProcessingHandler
-{
-    const HOST = 'logs-01.loggly.com';
-    const ENDPOINT_SINGLE = 'inputs';
-    const ENDPOINT_BATCH = 'bulk';
-
-    protected $token;
-
-    protected $tag;
-
-    public function __construct($token, $level = Logger::DEBUG, $bubble = true)
-    {
-        if (!extension_loaded('curl')) {
-            throw new \LogicException('The curl extension is needed to use the LogglyHandler');
-        }
-
-        $this->token = $token;
-
-        parent::__construct($level, $bubble);
-    }
-
-    public function setTag($tag)
-    {
-        $this->tag = $tag;
-    }
-
-    public function addTag($tag)
-    {
-        $this->tag = (strlen($this->tag) > 0) ? $this->tag .','. $tag : $tag;
-    }
-
-    protected function write(array $record)
-    {
-        $this->send($record["formatted"], self::ENDPOINT_SINGLE);
-    }
-
-    public function handleBatch(array $records)
-    {
-        $level = $this->level;
-
-        $records = array_filter($records, function ($record) use ($level) {
-            return ($record['level'] >= $level);
-        });
-
-        if ($records) {
-            $this->send($this->getFormatter()->formatBatch($records), self::ENDPOINT_BATCH);
-        }
-    }
-
-    protected function send($data, $endpoint)
-    {
-        $url = sprintf("https://%s/%s/%s/", self::HOST, $endpoint, $this->token);
-
-        $headers = array('Content-Type: application/json');
-
-        if ($this->tag) {
-            $headers[] = "X-LOGGLY-TAG: {$this->tag}";
-        }
-
-        $ch = curl_init();
-
-        curl_setopt($ch, CURLOPT_URL, $url);
-        curl_setopt($ch, CURLOPT_POST, true);
-        curl_setopt($ch, CURLOPT_POSTFIELDS, $data);
-        curl_setopt($ch, CURLOPT_HTTPHEADER, $headers);
-        curl_setopt($ch, CURLOPT_RETURNTRANSFER, true);
-
-        curl_exec($ch);
-        curl_close($ch);
-    }
-
-    protected function getDefaultFormatter()
-    {
-        return new LogglyFormatter();
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/MailHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/MailHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/MailHandler.php
deleted file mode 100644
index 50ed638..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/MailHandler.php
+++ /dev/null
@@ -1,55 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-/**
- * Base class for all mail handlers
- *
- * @author Gyula Sallai
- */
-abstract class MailHandler extends AbstractProcessingHandler
-{
-    /**
-     * {@inheritdoc}
-     */
-    public function handleBatch(array $records)
-    {
-        $messages = array();
-
-        foreach ($records as $record) {
-            if ($record['level'] < $this->level) {
-                continue;
-            }
-            $messages[] = $this->processRecord($record);
-        }
-
-        if (!empty($messages)) {
-            $this->send((string) $this->getFormatter()->formatBatch($messages), $messages);
-        }
-    }
-
-    /**
-     * Send a mail with the given content
-     *
-     * @param string $content formatted email body to be sent
-     * @param array  $records the array of log records that formed this content
-     */
-    abstract protected function send($content, array $records);
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        $this->send((string) $record['formatted'], array($record));
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/MandrillHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/MandrillHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/MandrillHandler.php
deleted file mode 100644
index 60a2901..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/MandrillHandler.php
+++ /dev/null
@@ -1,69 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * MandrillHandler uses cURL to send the emails to the Mandrill API
- *
- * @author Adam Nicholson <ad...@gmail.com>
- */
-class MandrillHandler extends MailHandler
-{
-    protected $client;
-    protected $message;
-
-    /**
-     * @param string                  $apiKey  A valid Mandrill API key
-     * @param callable|\Swift_Message $message An example message for real messages, only the body will be replaced
-     * @param integer                 $level   The minimum logging level at which this handler will be triggered
-     * @param Boolean                 $bubble  Whether the messages that are handled can bubble up the stack or not
-     */
-    public function __construct($apiKey, $message, $level = Logger::ERROR, $bubble = true)
-    {
-        parent::__construct($level, $bubble);
-
-        if (!$message instanceof \Swift_Message && is_callable($message)) {
-            $message = call_user_func($message);
-        }
-        if (!$message instanceof \Swift_Message) {
-            throw new \InvalidArgumentException('You must provide either a Swift_Message instance or a callable returning it');
-        }
-        $this->message = $message;
-        $this->apiKey = $apiKey;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function send($content, array $records)
-    {
-        $message = clone $this->message;
-        $message->setBody($content);
-        $message->setDate(time());
-
-        $ch = curl_init();
-
-        curl_setopt($ch, CURLOPT_URL, 'https://mandrillapp.com/api/1.0/messages/send-raw.json');
-        curl_setopt($ch, CURLOPT_POST, 1);
-        curl_setopt($ch, CURLOPT_RETURNTRANSFER, 1);
-        curl_setopt($ch, CURLOPT_POSTFIELDS, http_build_query(array(
-            'key' => $this->apiKey,
-            'raw_message' => (string) $message,
-            'async' => false,
-        )));
-
-        curl_exec($ch);
-        curl_close($ch);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/MissingExtensionException.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/MissingExtensionException.php b/vendor/monolog/monolog/src/Monolog/Handler/MissingExtensionException.php
deleted file mode 100644
index 4724a7e..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/MissingExtensionException.php
+++ /dev/null
@@ -1,21 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-/**
- * Exception can be thrown if an extension for an handler is missing
- *
- * @author  Christian Bergau <cb...@gmail.com>
- */
-class MissingExtensionException extends \Exception
-{
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/MongoDBHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/MongoDBHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/MongoDBHandler.php
deleted file mode 100644
index 6c431f2..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/MongoDBHandler.php
+++ /dev/null
@@ -1,55 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-use Monolog\Formatter\NormalizerFormatter;
-
-/**
- * Logs to a MongoDB database.
- *
- * usage example:
- *
- *   $log = new Logger('application');
- *   $mongodb = new MongoDBHandler(new \Mongo("mongodb://localhost:27017"), "logs", "prod");
- *   $log->pushHandler($mongodb);
- *
- * @author Thomas Tourlourat <th...@tourlourat.com>
- */
-class MongoDBHandler extends AbstractProcessingHandler
-{
-    protected $mongoCollection;
-
-    public function __construct($mongo, $database, $collection, $level = Logger::DEBUG, $bubble = true)
-    {
-        if (!($mongo instanceof \MongoClient || $mongo instanceof \Mongo)) {
-            throw new \InvalidArgumentException('MongoClient or Mongo instance required');
-        }
-
-        $this->mongoCollection = $mongo->selectCollection($database, $collection);
-
-        parent::__construct($level, $bubble);
-    }
-
-    protected function write(array $record)
-    {
-        $this->mongoCollection->save($record["formatted"]);
-    }
-
-    /**
-     * {@inheritDoc}
-     */
-    protected function getDefaultFormatter()
-    {
-        return new NormalizerFormatter();
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/NativeMailerHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/NativeMailerHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/NativeMailerHandler.php
deleted file mode 100644
index 5118a0e..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/NativeMailerHandler.php
+++ /dev/null
@@ -1,176 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * NativeMailerHandler uses the mail() function to send the emails
- *
- * @author Christophe Coevoet <st...@notk.org>
- * @author Mark Garrett <ma...@moderndeveloperllc.com>
- */
-class NativeMailerHandler extends MailHandler
-{
-    /**
-     * The email addresses to which the message will be sent
-     * @var array
-     */
-    protected $to;
-
-    /**
-     * The subject of the email
-     * @var string
-     */
-    protected $subject;
-
-    /**
-     * Optional headers for the message
-     * @var array
-     */
-    protected $headers = array();
-
-    /**
-     * Optional parameters for the message
-     * @var array
-     */
-    protected $parameters = array();
-
-    /**
-     * The wordwrap length for the message
-     * @var integer
-     */
-    protected $maxColumnWidth;
-
-    /**
-     * The Content-type for the message
-     * @var string
-     */
-    protected $contentType = 'text/plain';
-
-    /**
-     * The encoding for the message
-     * @var string
-     */
-    protected $encoding = 'utf-8';
-
-    /**
-     * @param string|array $to             The receiver of the mail
-     * @param string       $subject        The subject of the mail
-     * @param string       $from           The sender of the mail
-     * @param integer      $level          The minimum logging level at which this handler will be triggered
-     * @param boolean      $bubble         Whether the messages that are handled can bubble up the stack or not
-     * @param int          $maxColumnWidth The maximum column width that the message lines will have
-     */
-    public function __construct($to, $subject, $from, $level = Logger::ERROR, $bubble = true, $maxColumnWidth = 70)
-    {
-        parent::__construct($level, $bubble);
-        $this->to = is_array($to) ? $to : array($to);
-        $this->subject = $subject;
-        $this->addHeader(sprintf('From: %s', $from));
-        $this->maxColumnWidth = $maxColumnWidth;
-    }
-
-    /**
-     * Add headers to the message
-     *
-     * @param  string|array $headers Custom added headers
-     * @return self
-     */
-    public function addHeader($headers)
-    {
-        foreach ((array) $headers as $header) {
-            if (strpos($header, "\n") !== false || strpos($header, "\r") !== false) {
-                throw new \InvalidArgumentException('Headers can not contain newline characters for security reasons');
-            }
-            $this->headers[] = $header;
-        }
-
-        return $this;
-    }
-
-    /**
-     * Add parameters to the message
-     *
-     * @param string|array $parameters Custom added parameters
-     * @return self
-     */
-    public function addParameter($parameters)
-    {
-        $this->parameters = array_merge($this->parameters, (array) $parameters);
-
-        return $this;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function send($content, array $records)
-    {
-        $content = wordwrap($content, $this->maxColumnWidth);
-        $headers = ltrim(implode("\r\n", $this->headers) . "\r\n", "\r\n");
-        $headers .= 'Content-type: ' . $this->getContentType() . '; charset=' . $this->getEncoding() . "\r\n";
-        if ($this->getContentType() == 'text/html' && false === strpos($headers, 'MIME-Version:')) {
-            $headers .= 'MIME-Version: 1.0' . "\r\n";
-        }
-        foreach ($this->to as $to) {
-            mail($to, $this->subject, $content, $headers, implode(' ', $this->parameters));
-        }
-    }
-
-    /**
-     * @return string $contentType
-     */
-    public function getContentType()
-    {
-        return $this->contentType;
-    }
-
-    /**
-     * @return string $encoding
-     */
-    public function getEncoding()
-    {
-        return $this->encoding;
-    }
-
-    /**
-     * @param  string $contentType The content type of the email - Defaults to text/plain. Use text/html for HTML
-     *                             messages.
-     * @return self
-     */
-    public function setContentType($contentType)
-    {
-        if (strpos($contentType, "\n") !== false || strpos($contentType, "\r") !== false) {
-            throw new \InvalidArgumentException('The content type can not contain newline characters to prevent email header injection');
-        }
-
-        $this->contentType = $contentType;
-
-        return $this;
-    }
-
-    /**
-     * @param  string $encoding
-     * @return self
-     */
-    public function setEncoding($encoding)
-    {
-        if (strpos($encoding, "\n") !== false || strpos($encoding, "\r") !== false) {
-            throw new \InvalidArgumentException('The encoding can not contain newline characters to prevent email header injection');
-        }
-
-        $this->encoding = $encoding;
-
-        return $this;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/NewRelicHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/NewRelicHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/NewRelicHandler.php
deleted file mode 100644
index 0c26794..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/NewRelicHandler.php
+++ /dev/null
@@ -1,176 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * Class to record a log on a NewRelic application.
- * Enabling New Relic High Security mode may prevent capture of useful information.
- *
- * @see https://docs.newrelic.com/docs/agents/php-agent
- * @see https://docs.newrelic.com/docs/accounts-partnerships/accounts/security/high-security
- */
-class NewRelicHandler extends AbstractProcessingHandler
-{
-    /**
-     * Name of the New Relic application that will receive logs from this handler.
-     *
-     * @var string
-     */
-    protected $appName;
-
-    /**
-     * Name of the current transaction
-     *
-     * @var string
-     */
-    protected $transactionName;
-
-    /**
-     * Some context and extra data is passed into the handler as arrays of values. Do we send them as is
-     * (useful if we are using the API), or explode them for display on the NewRelic RPM website?
-     *
-     * @var boolean
-     */
-    protected $explodeArrays;
-
-    /**
-     * {@inheritDoc}
-     *
-     * @param string  $appName
-     * @param boolean $explodeArrays
-     * @param string  $transactionName
-     */
-    public function __construct(
-        $level = Logger::ERROR,
-        $bubble = true,
-        $appName = null,
-        $explodeArrays = false,
-        $transactionName = null
-    ) {
-        parent::__construct($level, $bubble);
-
-        $this->appName       = $appName;
-        $this->explodeArrays = $explodeArrays;
-        $this->transactionName = $transactionName;
-    }
-
-    /**
-     * {@inheritDoc}
-     */
-    protected function write(array $record)
-    {
-        if (!$this->isNewRelicEnabled()) {
-            throw new MissingExtensionException('The newrelic PHP extension is required to use the NewRelicHandler');
-        }
-
-        if ($appName = $this->getAppName($record['context'])) {
-            $this->setNewRelicAppName($appName);
-        }
-
-        if ($transactionName = $this->getTransactionName($record['context'])) {
-            $this->setNewRelicTransactionName($transactionName);
-            unset($record['context']['transaction_name']);
-        }
-
-        if (isset($record['context']['exception']) && $record['context']['exception'] instanceof \Exception) {
-            newrelic_notice_error($record['message'], $record['context']['exception']);
-            unset($record['context']['exception']);
-        } else {
-            newrelic_notice_error($record['message']);
-        }
-
-        foreach ($record['context'] as $key => $parameter) {
-            if (is_array($parameter) && $this->explodeArrays) {
-                foreach ($parameter as $paramKey => $paramValue) {
-                    newrelic_add_custom_parameter('context_' . $key . '_' . $paramKey, $paramValue);
-                }
-            } else {
-                newrelic_add_custom_parameter('context_' . $key, $parameter);
-            }
-        }
-
-        foreach ($record['extra'] as $key => $parameter) {
-            if (is_array($parameter) && $this->explodeArrays) {
-                foreach ($parameter as $paramKey => $paramValue) {
-                    newrelic_add_custom_parameter('extra_' . $key . '_' . $paramKey, $paramValue);
-                }
-            } else {
-                newrelic_add_custom_parameter('extra_' . $key, $parameter);
-            }
-        }
-    }
-
-    /**
-     * Checks whether the NewRelic extension is enabled in the system.
-     *
-     * @return bool
-     */
-    protected function isNewRelicEnabled()
-    {
-        return extension_loaded('newrelic');
-    }
-
-    /**
-     * Returns the appname where this log should be sent. Each log can override the default appname, set in this
-     * handler's constructor, by providing the appname in it's context.
-     *
-     * @param  array       $context
-     * @return null|string
-     */
-    protected function getAppName(array $context)
-    {
-        if (isset($context['appname'])) {
-            return $context['appname'];
-        }
-
-        return $this->appName;
-    }
-
-    /**
-     * Returns the name of the current transaction. Each log can override the default transaction name, set in this
-     * handler's constructor, by providing the transaction_name in it's context
-     *
-     * @param array $context
-     *
-     * @return null|string
-     */
-    protected function getTransactionName(array $context)
-    {
-        if (isset($context['transaction_name'])) {
-            return $context['transaction_name'];
-        }
-
-        return $this->transactionName;
-    }
-
-    /**
-     * Sets the NewRelic application that should receive this log.
-     *
-     * @param string $appName
-     */
-    protected function setNewRelicAppName($appName)
-    {
-        newrelic_set_appname($appName);
-    }
-
-    /**
-     * Overwrites the name of the current transaction
-     *
-     * @param $transactionName
-     */
-    protected function setNewRelicTransactionName($transactionName)
-    {
-        newrelic_name_transaction($transactionName);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/NullHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/NullHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/NullHandler.php
deleted file mode 100644
index 3754e45..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/NullHandler.php
+++ /dev/null
@@ -1,45 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * Blackhole
- *
- * Any record it can handle will be thrown away. This can be used
- * to put on top of an existing stack to override it temporarily.
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class NullHandler extends AbstractHandler
-{
-    /**
-     * @param integer $level The minimum logging level at which this handler will be triggered
-     */
-    public function __construct($level = Logger::DEBUG)
-    {
-        parent::__construct($level, false);
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function handle(array $record)
-    {
-        if ($record['level'] < $this->level) {
-            return false;
-        }
-
-        return true;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/PsrHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/PsrHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/PsrHandler.php
deleted file mode 100644
index 1ae8584..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/PsrHandler.php
+++ /dev/null
@@ -1,56 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-use Psr\Log\LoggerInterface;
-
-/**
- * Proxies log messages to an existing PSR-3 compliant logger.
- *
- * @author Michael Moussa <mi...@gmail.com>
- */
-class PsrHandler extends AbstractHandler
-{
-    /**
-     * PSR-3 compliant logger
-     *
-     * @var LoggerInterface
-     */
-    protected $logger;
-
-    /**
-     * @param LoggerInterface $logger The underlying PSR-3 compliant logger to which messages will be proxied
-     * @param int             $level  The minimum logging level at which this handler will be triggered
-     * @param Boolean         $bubble Whether the messages that are handled can bubble up the stack or not
-     */
-    public function __construct(LoggerInterface $logger, $level = Logger::DEBUG, $bubble = true)
-    {
-        parent::__construct($level, $bubble);
-
-        $this->logger = $logger;
-    }
-
-    /**
-     * {@inheritDoc}
-     */
-    public function handle(array $record)
-    {
-        if (!$this->isHandling($record)) {
-            return false;
-        }
-
-        $this->logger->log(strtolower($record['level_name']), $record['message'], $record['context']);
-
-        return false === $this->bubble;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/PushoverHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/PushoverHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/PushoverHandler.php
deleted file mode 100644
index cd2fcfa..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/PushoverHandler.php
+++ /dev/null
@@ -1,172 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * Sends notifications through the pushover api to mobile phones
- *
- * @author Sebastian Göttschkes <se...@googlemail.com>
- * @see    https://www.pushover.net/api
- */
-class PushoverHandler extends SocketHandler
-{
-    private $token;
-    private $users;
-    private $title;
-    private $user;
-    private $retry;
-    private $expire;
-
-    private $highPriorityLevel;
-    private $emergencyLevel;
-
-    /**
-     * All parameters that can be sent to Pushover
-     * @see https://pushover.net/api
-     * @var array
-     */
-    private $parameterNames = array(
-        'token' => true,
-        'user' => true,
-        'message' => true,
-        'device' => true,
-        'title' => true,
-        'url' => true,
-        'url_title' => true,
-        'priority' => true,
-        'timestamp' => true,
-        'sound' => true,
-        'retry' => true,
-        'expire' => true,
-        'callback' => true,
-    );
-
-    /**
-     * Sounds the api supports by default
-     * @see https://pushover.net/api#sounds
-     * @var array
-     */
-    private $sounds = array(
-        'pushover', 'bike', 'bugle', 'cashregister', 'classical', 'cosmic', 'falling', 'gamelan', 'incoming',
-        'intermission', 'magic', 'mechanical', 'pianobar', 'siren', 'spacealarm', 'tugboat', 'alien', 'climb',
-        'persistent', 'echo', 'updown', 'none',
-    );
-
-    /**
-     * @param string       $token             Pushover api token
-     * @param string|array $users             Pushover user id or array of ids the message will be sent to
-     * @param string       $title             Title sent to the Pushover API
-     * @param integer      $level             The minimum logging level at which this handler will be triggered
-     * @param Boolean      $bubble            Whether the messages that are handled can bubble up the stack or not
-     * @param Boolean      $useSSL            Whether to connect via SSL. Required when pushing messages to users that are not
-     *                                        the pushover.net app owner. OpenSSL is required for this option.
-     * @param integer      $highPriorityLevel The minimum logging level at which this handler will start
-     *                                        sending "high priority" requests to the Pushover API
-     * @param integer      $emergencyLevel    The minimum logging level at which this handler will start
-     *                                        sending "emergency" requests to the Pushover API
-     * @param integer      $retry             The retry parameter specifies how often (in seconds) the Pushover servers will send the same notification to the user.
-     * @param integer      $expire            The expire parameter specifies how many seconds your notification will continue to be retried for (every retry seconds).
-     */
-    public function __construct($token, $users, $title = null, $level = Logger::CRITICAL, $bubble = true, $useSSL = true, $highPriorityLevel = Logger::CRITICAL, $emergencyLevel = Logger::EMERGENCY, $retry = 30, $expire = 25200)
-    {
-        $connectionString = $useSSL ? 'ssl://api.pushover.net:443' : 'api.pushover.net:80';
-        parent::__construct($connectionString, $level, $bubble);
-
-        $this->token = $token;
-        $this->users = (array) $users;
-        $this->title = $title ?: gethostname();
-        $this->highPriorityLevel = Logger::toMonologLevel($highPriorityLevel);
-        $this->emergencyLevel = Logger::toMonologLevel($emergencyLevel);
-        $this->retry = $retry;
-        $this->expire = $expire;
-    }
-
-    protected function generateDataStream($record)
-    {
-        $content = $this->buildContent($record);
-
-        return $this->buildHeader($content) . $content;
-    }
-
-    private function buildContent($record)
-    {
-        // Pushover has a limit of 512 characters on title and message combined.
-        $maxMessageLength = 512 - strlen($this->title);
-        $message = substr($record['message'], 0, $maxMessageLength);
-        $timestamp = $record['datetime']->getTimestamp();
-
-        $dataArray = array(
-            'token' => $this->token,
-            'user' => $this->user,
-            'message' => $message,
-            'title' => $this->title,
-            'timestamp' => $timestamp
-        );
-
-        if (isset($record['level']) && $record['level'] >= $this->emergencyLevel) {
-            $dataArray['priority'] = 2;
-            $dataArray['retry'] = $this->retry;
-            $dataArray['expire'] = $this->expire;
-        } elseif (isset($record['level']) && $record['level'] >= $this->highPriorityLevel) {
-            $dataArray['priority'] = 1;
-        }
-
-        // First determine the available parameters
-        $context = array_intersect_key($record['context'], $this->parameterNames);
-        $extra = array_intersect_key($record['extra'], $this->parameterNames);
-
-        // Least important info should be merged with subsequent info
-        $dataArray = array_merge($extra, $context, $dataArray);
-
-        // Only pass sounds that are supported by the API
-        if (isset($dataArray['sound']) && !in_array($dataArray['sound'], $this->sounds)) {
-            unset($dataArray['sound']);
-        }
-
-        return http_build_query($dataArray);
-    }
-
-    private function buildHeader($content)
-    {
-        $header = "POST /1/messages.json HTTP/1.1\r\n";
-        $header .= "Host: api.pushover.net\r\n";
-        $header .= "Content-Type: application/x-www-form-urlencoded\r\n";
-        $header .= "Content-Length: " . strlen($content) . "\r\n";
-        $header .= "\r\n";
-
-        return $header;
-    }
-
-    protected function write(array $record)
-    {
-        foreach ($this->users as $user) {
-            $this->user = $user;
-
-            parent::write($record);
-            $this->closeSocket();
-        }
-
-        $this->user = null;
-    }
-
-    public function setHighPriorityLevel($value)
-    {
-        $this->highPriorityLevel = $value;
-    }
-
-    public function setEmergencyLevel($value)
-    {
-        $this->emergencyLevel = $value;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/RavenHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/RavenHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/RavenHandler.php
deleted file mode 100644
index 69da8ca..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/RavenHandler.php
+++ /dev/null
@@ -1,187 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Formatter\LineFormatter;
-use Monolog\Formatter\FormatterInterface;
-use Monolog\Logger;
-use Raven_Client;
-
-/**
- * Handler to send messages to a Sentry (https://github.com/getsentry/sentry) server
- * using raven-php (https://github.com/getsentry/raven-php)
- *
- * @author Marc Abramowitz <ma...@marc-abramowitz.com>
- */
-class RavenHandler extends AbstractProcessingHandler
-{
-    /**
-     * Translates Monolog log levels to Raven log levels.
-     */
-    private $logLevels = array(
-        Logger::DEBUG     => Raven_Client::DEBUG,
-        Logger::INFO      => Raven_Client::INFO,
-        Logger::NOTICE    => Raven_Client::INFO,
-        Logger::WARNING   => Raven_Client::WARNING,
-        Logger::ERROR     => Raven_Client::ERROR,
-        Logger::CRITICAL  => Raven_Client::FATAL,
-        Logger::ALERT     => Raven_Client::FATAL,
-        Logger::EMERGENCY => Raven_Client::FATAL,
-    );
-
-    /**
-     * @var Raven_Client the client object that sends the message to the server
-     */
-    protected $ravenClient;
-
-    /**
-     * @var LineFormatter The formatter to use for the logs generated via handleBatch()
-     */
-    protected $batchFormatter;
-
-    /**
-     * @param Raven_Client $ravenClient
-     * @param integer      $level       The minimum logging level at which this handler will be triggered
-     * @param Boolean      $bubble      Whether the messages that are handled can bubble up the stack or not
-     */
-    public function __construct(Raven_Client $ravenClient, $level = Logger::DEBUG, $bubble = true)
-    {
-        parent::__construct($level, $bubble);
-
-        $this->ravenClient = $ravenClient;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function handleBatch(array $records)
-    {
-        $level = $this->level;
-
-        // filter records based on their level
-        $records = array_filter($records, function ($record) use ($level) {
-            return $record['level'] >= $level;
-        });
-
-        if (!$records) {
-            return;
-        }
-
-        // the record with the highest severity is the "main" one
-        $record = array_reduce($records, function ($highest, $record) {
-            if ($record['level'] >= $highest['level']) {
-                return $record;
-            }
-
-            return $highest;
-        });
-
-        // the other ones are added as a context item
-        $logs = array();
-        foreach ($records as $r) {
-            $logs[] = $this->processRecord($r);
-        }
-
-        if ($logs) {
-            $record['context']['logs'] = (string) $this->getBatchFormatter()->formatBatch($logs);
-        }
-
-        $this->handle($record);
-    }
-
-    /**
-     * Sets the formatter for the logs generated by handleBatch().
-     *
-     * @param FormatterInterface $formatter
-     */
-    public function setBatchFormatter(FormatterInterface $formatter)
-    {
-        $this->batchFormatter = $formatter;
-    }
-
-    /**
-     * Gets the formatter for the logs generated by handleBatch().
-     *
-     * @return FormatterInterface
-     */
-    public function getBatchFormatter()
-    {
-        if (!$this->batchFormatter) {
-            $this->batchFormatter = $this->getDefaultBatchFormatter();
-        }
-
-        return $this->batchFormatter;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        // ensures user context is empty
-        $this->ravenClient->user_context(null);
-        $options = array();
-        $options['level'] = $this->logLevels[$record['level']];
-        $options['tags'] = array();
-        if (!empty($record['extra']['tags'])) {
-            $options['tags'] = array_merge($options['tags'], $record['extra']['tags']);
-            unset($record['extra']['tags']);
-        }
-        if (!empty($record['context']['tags'])) {
-            $options['tags'] = array_merge($options['tags'], $record['context']['tags']);
-            unset($record['context']['tags']);
-        }
-        if (!empty($record['context']['logger'])) {
-            $options['logger'] = $record['context']['logger'];
-            unset($record['context']['logger']);
-        } else {
-            $options['logger'] = $record['channel'];
-        }
-        if (!empty($record['context'])) {
-            $options['extra']['context'] = $record['context'];
-            if (!empty($record['context']['user'])) {
-                $this->ravenClient->user_context($record['context']['user']);
-                unset($options['extra']['context']['user']);
-            }
-        }
-        if (!empty($record['extra'])) {
-            $options['extra']['extra'] = $record['extra'];
-        }
-
-        if (isset($record['context']['exception']) && $record['context']['exception'] instanceof \Exception) {
-            $options['extra']['message'] = $record['formatted'];
-            $this->ravenClient->captureException($record['context']['exception'], $options);
-
-            return;
-        }
-
-        $this->ravenClient->captureMessage($record['formatted'], array(), $options);
-    }
-
-    /**
-     * {@inheritDoc}
-     */
-    protected function getDefaultFormatter()
-    {
-        return new LineFormatter('[%channel%] %message%');
-    }
-
-    /**
-     * Gets the default formatter for the logs generated by handleBatch().
-     *
-     * @return FormatterInterface
-     */
-    protected function getDefaultBatchFormatter()
-    {
-        return new LineFormatter();
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/RedisHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/RedisHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/RedisHandler.php
deleted file mode 100644
index 3fc7f34..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/RedisHandler.php
+++ /dev/null
@@ -1,58 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-use Monolog\Formatter\LineFormatter;
-
-/**
- * Logs to a Redis key using rpush
- *
- * usage example:
- *
- *   $log = new Logger('application');
- *   $redis = new RedisHandler(new Predis\Client("tcp://localhost:6379"), "logs", "prod");
- *   $log->pushHandler($redis);
- *
- * @author Thomas Tourlourat <th...@tourlourat.com>
- */
-class RedisHandler extends AbstractProcessingHandler
-{
-    private $redisClient;
-    private $redisKey;
-
-    # redis instance, key to use
-    public function __construct($redis, $key, $level = Logger::DEBUG, $bubble = true)
-    {
-        if (!(($redis instanceof \Predis\Client) || ($redis instanceof \Redis))) {
-            throw new \InvalidArgumentException('Predis\Client or Redis instance required');
-        }
-
-        $this->redisClient = $redis;
-        $this->redisKey = $key;
-
-        parent::__construct($level, $bubble);
-    }
-
-    protected function write(array $record)
-    {
-        $this->redisClient->rpush($this->redisKey, $record["formatted"]);
-    }
-
-    /**
-     * {@inheritDoc}
-     */
-    protected function getDefaultFormatter()
-    {
-        return new LineFormatter();
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/RollbarHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/RollbarHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/RollbarHandler.php
deleted file mode 100644
index 81abf08..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/RollbarHandler.php
+++ /dev/null
@@ -1,73 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use RollbarNotifier;
-use Exception;
-use Monolog\Logger;
-
-/**
- * Sends errors to Rollbar
- *
- * @author Paul Statezny <pa...@gmail.com>
- */
-class RollbarHandler extends AbstractProcessingHandler
-{
-    /**
-     * Rollbar notifier
-     *
-     * @var RollbarNotifier
-     */
-    protected $rollbarNotifier;
-
-    /**
-     * @param RollbarNotifier $rollbarNotifier RollbarNotifier object constructed with valid token
-     * @param integer         $level           The minimum logging level at which this handler will be triggered
-     * @param boolean         $bubble          Whether the messages that are handled can bubble up the stack or not
-     */
-    public function __construct(RollbarNotifier $rollbarNotifier, $level = Logger::ERROR, $bubble = true)
-    {
-        $this->rollbarNotifier = $rollbarNotifier;
-
-        parent::__construct($level, $bubble);
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        if (isset($record['context']['exception']) && $record['context']['exception'] instanceof Exception) {
-            $this->rollbarNotifier->report_exception($record['context']['exception']);
-        } else {
-            $extraData = array(
-                'level' => $record['level'],
-                'channel' => $record['channel'],
-                'datetime' => $record['datetime']->format('U'),
-            );
-
-            $this->rollbarNotifier->report_message(
-                $record['message'],
-                $record['level_name'],
-                array_merge($record['context'], $record['extra'], $extraData)
-            );
-        }
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function close()
-    {
-        $this->rollbarNotifier->flush();
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/RotatingFileHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/RotatingFileHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/RotatingFileHandler.php
deleted file mode 100644
index 4168c32..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/RotatingFileHandler.php
+++ /dev/null
@@ -1,153 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * Stores logs to files that are rotated every day and a limited number of files are kept.
- *
- * This rotation is only intended to be used as a workaround. Using logrotate to
- * handle the rotation is strongly encouraged when you can use it.
- *
- * @author Christophe Coevoet <st...@notk.org>
- * @author Jordi Boggiano <j....@seld.be>
- */
-class RotatingFileHandler extends StreamHandler
-{
-    protected $filename;
-    protected $maxFiles;
-    protected $mustRotate;
-    protected $nextRotation;
-    protected $filenameFormat;
-    protected $dateFormat;
-
-    /**
-     * @param string   $filename
-     * @param integer  $maxFiles       The maximal amount of files to keep (0 means unlimited)
-     * @param integer  $level          The minimum logging level at which this handler will be triggered
-     * @param Boolean  $bubble         Whether the messages that are handled can bubble up the stack or not
-     * @param int|null $filePermission Optional file permissions (default (0644) are only for owner read/write)
-     * @param Boolean  $useLocking     Try to lock log file before doing any writes
-     */
-    public function __construct($filename, $maxFiles = 0, $level = Logger::DEBUG, $bubble = true, $filePermission = null, $useLocking = false)
-    {
-        $this->filename = $filename;
-        $this->maxFiles = (int) $maxFiles;
-        $this->nextRotation = new \DateTime('tomorrow');
-        $this->filenameFormat = '{filename}-{date}';
-        $this->dateFormat = 'Y-m-d';
-
-        parent::__construct($this->getTimedFilename(), $level, $bubble, $filePermission, $useLocking);
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function close()
-    {
-        parent::close();
-
-        if (true === $this->mustRotate) {
-            $this->rotate();
-        }
-    }
-
-    public function setFilenameFormat($filenameFormat, $dateFormat)
-    {
-        $this->filenameFormat = $filenameFormat;
-        $this->dateFormat = $dateFormat;
-        $this->url = $this->getTimedFilename();
-        $this->close();
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        // on the first record written, if the log is new, we should rotate (once per day)
-        if (null === $this->mustRotate) {
-            $this->mustRotate = !file_exists($this->url);
-        }
-
-        if ($this->nextRotation < $record['datetime']) {
-            $this->mustRotate = true;
-            $this->close();
-        }
-
-        parent::write($record);
-    }
-
-    /**
-     * Rotates the files.
-     */
-    protected function rotate()
-    {
-        // update filename
-        $this->url = $this->getTimedFilename();
-        $this->nextRotation = new \DateTime('tomorrow');
-
-        // skip GC of old logs if files are unlimited
-        if (0 === $this->maxFiles) {
-            return;
-        }
-
-        $logFiles = glob($this->getGlobPattern());
-        if ($this->maxFiles >= count($logFiles)) {
-            // no files to remove
-            return;
-        }
-
-        // Sorting the files by name to remove the older ones
-        usort($logFiles, function ($a, $b) {
-            return strcmp($b, $a);
-        });
-
-        foreach (array_slice($logFiles, $this->maxFiles) as $file) {
-            if (is_writable($file)) {
-                unlink($file);
-            }
-        }
-    }
-
-    protected function getTimedFilename()
-    {
-        $fileInfo = pathinfo($this->filename);
-        $timedFilename = str_replace(
-            array('{filename}', '{date}'),
-            array($fileInfo['filename'], date($this->dateFormat)),
-            $fileInfo['dirname'] . '/' . $this->filenameFormat
-        );
-
-        if (!empty($fileInfo['extension'])) {
-            $timedFilename .= '.'.$fileInfo['extension'];
-        }
-
-        return $timedFilename;
-    }
-
-    protected function getGlobPattern()
-    {
-        $fileInfo = pathinfo($this->filename);
-        $glob = str_replace(
-            array('{filename}', '{date}'),
-            array($fileInfo['filename'], '*'),
-            $fileInfo['dirname'] . '/' . $this->filenameFormat
-        );
-        if (!empty($fileInfo['extension'])) {
-            $glob .= '.'.$fileInfo['extension'];
-        }
-
-        return $glob;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/SamplingHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/SamplingHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/SamplingHandler.php
deleted file mode 100644
index 9509ae3..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/SamplingHandler.php
+++ /dev/null
@@ -1,82 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-/**
- * Sampling handler
- *
- * A sampled event stream can be useful for logging high frequency events in
- * a production environment where you only need an idea of what is happening
- * and are not concerned with capturing every occurrence. Since the decision to
- * handle or not handle a particular event is determined randomly, the
- * resulting sampled log is not guaranteed to contain 1/N of the events that
- * occurred in the application, but based on the Law of large numbers, it will
- * tend to be close to this ratio with a large number of attempts.
- *
- * @author Bryan Davis <bd...@wikimedia.org>
- * @author Kunal Mehta <le...@gmail.com>
- */
-class SamplingHandler extends AbstractHandler
-{
-    /**
-     * @var callable|HandlerInterface $handler
-     */
-    protected $handler;
-
-    /**
-     * @var int $factor
-     */
-    protected $factor;
-
-    /**
-     * @param callable|HandlerInterface $handler Handler or factory callable($record, $fingersCrossedHandler).
-     * @param int                       $factor  Sample factor
-     */
-    public function __construct($handler, $factor)
-    {
-        parent::__construct();
-        $this->handler = $handler;
-        $this->factor = $factor;
-
-        if (!$this->handler instanceof HandlerInterface && !is_callable($this->handler)) {
-            throw new \RuntimeException("The given handler (".json_encode($this->handler).") is not a callable nor a Monolog\Handler\HandlerInterface object");
-        }
-    }
-
-    public function isHandling(array $record)
-    {
-        return $this->handler->isHandling($record);
-    }
-
-    public function handle(array $record)
-    {
-        if ($this->isHandling($record) && mt_rand(1, $this->factor) === 1) {
-            // The same logic as in FingersCrossedHandler
-            if (!$this->handler instanceof HandlerInterface) {
-                $this->handler = call_user_func($this->handler, $record, $this);
-                if (!$this->handler instanceof HandlerInterface) {
-                    throw new \RuntimeException("The factory callable should return a HandlerInterface");
-                }
-            }
-
-            if ($this->processors) {
-                foreach ($this->processors as $processor) {
-                    $record = call_user_func($processor, $record);
-                }
-            }
-
-            $this->handler->handle($record);
-        }
-
-        return false === $this->bubble;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/SlackHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/SlackHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/SlackHandler.php
deleted file mode 100644
index 7328dee..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/SlackHandler.php
+++ /dev/null
@@ -1,280 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-use Monolog\Formatter\LineFormatter;
-
-/**
- * Sends notifications through Slack API
- *
- * @author Greg Kedzierski <gr...@gregkedzierski.com>
- * @see    https://api.slack.com/
- */
-class SlackHandler extends SocketHandler
-{
-    /**
-     * Slack API token
-     * @var string
-     */
-    private $token;
-
-    /**
-     * Slack channel (encoded ID or name)
-     * @var string
-     */
-    private $channel;
-
-    /**
-     * Name of a bot
-     * @var string
-     */
-    private $username;
-
-    /**
-     * Emoji icon name
-     * @var string
-     */
-    private $iconEmoji;
-
-    /**
-     * Whether the message should be added to Slack as attachment (plain text otherwise)
-     * @var bool
-     */
-    private $useAttachment;
-
-    /**
-     * Whether the the context/extra messages added to Slack as attachments are in a short style
-     * @var bool
-     */
-    private $useShortAttachment;
-
-    /**
-     * Whether the attachment should include context and extra data
-     * @var bool
-     */
-    private $includeContextAndExtra;
-
-    /**
-     * @var LineFormatter
-     */
-    private $lineFormatter;
-
-    /**
-     * @param string      $token                  Slack API token
-     * @param string      $channel                Slack channel (encoded ID or name)
-     * @param string      $username               Name of a bot
-     * @param bool        $useAttachment          Whether the message should be added to Slack as attachment (plain text otherwise)
-     * @param string|null $iconEmoji              The emoji name to use (or null)
-     * @param int         $level                  The minimum logging level at which this handler will be triggered
-     * @param bool        $bubble                 Whether the messages that are handled can bubble up the stack or not
-     * @param bool        $useShortAttachment     Whether the the context/extra messages added to Slack as attachments are in a short style
-     * @param bool        $includeContextAndExtra Whether the attachment should include context and extra data
-     */
-    public function __construct($token, $channel, $username = 'Monolog', $useAttachment = true, $iconEmoji = null, $level = Logger::CRITICAL, $bubble = true, $useShortAttachment = false, $includeContextAndExtra = false)
-    {
-        if (!extension_loaded('openssl')) {
-            throw new MissingExtensionException('The OpenSSL PHP extension is required to use the SlackHandler');
-        }
-
-        parent::__construct('ssl://slack.com:443', $level, $bubble);
-
-        $this->token = $token;
-        $this->channel = $channel;
-        $this->username = $username;
-        $this->iconEmoji = trim($iconEmoji, ':');
-        $this->useAttachment = $useAttachment;
-        $this->useShortAttachment = $useShortAttachment;
-        $this->includeContextAndExtra = $includeContextAndExtra;
-        if ($this->includeContextAndExtra) {
-            $this->lineFormatter = new LineFormatter;
-        }
-    }
-
-    /**
-     * {@inheritdoc}
-     *
-     * @param  array  $record
-     * @return string
-     */
-    protected function generateDataStream($record)
-    {
-        $content = $this->buildContent($record);
-
-        return $this->buildHeader($content) . $content;
-    }
-
-    /**
-     * Builds the body of API call
-     *
-     * @param  array  $record
-     * @return string
-     */
-    private function buildContent($record)
-    {
-        $dataArray = array(
-            'token' => $this->token,
-            'channel' => $this->channel,
-            'username' => $this->username,
-            'text' => '',
-            'attachments' => array()
-        );
-
-        if ($this->useAttachment) {
-            $attachment = array(
-                'fallback' => $record['message'],
-                'color' => $this->getAttachmentColor($record['level'])
-            );
-
-            if ($this->useShortAttachment) {
-                $attachment['fields'] = array(
-                    array(
-                        'title' => $record['level_name'],
-                        'value' => $record['message'],
-                        'short' => false
-                    )
-                );
-            } else {
-                $attachment['fields'] = array(
-                    array(
-                        'title' => 'Message',
-                        'value' => $record['message'],
-                        'short' => false
-                    ),
-                    array(
-                        'title' => 'Level',
-                        'value' => $record['level_name'],
-                        'short' => true
-                    )
-                );
-            }
-
-            if ($this->includeContextAndExtra) {
-                if (!empty($record['extra'])) {
-                    if ($this->useShortAttachment) {
-                        $attachment['fields'][] = array(
-                            'title' => "Extra",
-                            'value' => $this->stringify($record['extra']),
-                            'short' => $this->useShortAttachment
-                        );
-                    } else {
-                        // Add all extra fields as individual fields in attachment
-                        foreach ($record['extra'] as $var => $val) {
-                            $attachment['fields'][] = array(
-                                'title' => $var,
-                                'value' => $val,
-                                'short' => $this->useShortAttachment
-                           );
-                        }
-                    }
-                }
-
-                if (!empty($record['context'])) {
-                    if ($this->useShortAttachment) {
-                        $attachment['fields'][] = array(
-                            'title' => "Context",
-                            'value' => $this->stringify($record['context']),
-                            'short' => $this->useShortAttachment
-                        );
-                    } else {
-                        // Add all context fields as individual fields in attachment
-                        foreach ($record['context'] as $var => $val) {
-                            $attachment['fields'][] = array(
-                                'title' => $var,
-                                'value' => $val,
-                                'short' => $this->useShortAttachment
-                           );
-                        }
-                    }
-                }
-            }
-
-            $dataArray['attachments'] = json_encode(array($attachment));
-        } else {
-            $dataArray['text'] = $record['message'];
-        }
-
-        if ($this->iconEmoji) {
-            $dataArray['icon_emoji'] = ":{$this->iconEmoji}:";
-        }
-
-        return http_build_query($dataArray);
-    }
-
-    /**
-     * Builds the header of the API Call
-     *
-     * @param  string $content
-     * @return string
-     */
-    private function buildHeader($content)
-    {
-        $header = "POST /api/chat.postMessage HTTP/1.1\r\n";
-        $header .= "Host: slack.com\r\n";
-        $header .= "Content-Type: application/x-www-form-urlencoded\r\n";
-        $header .= "Content-Length: " . strlen($content) . "\r\n";
-        $header .= "\r\n";
-
-        return $header;
-    }
-
-    /**
-     * {@inheritdoc}
-     *
-     * @param array $record
-     */
-    protected function write(array $record)
-    {
-        parent::write($record);
-        $this->closeSocket();
-    }
-
-    /**
-     * Returned a Slack message attachment color associated with
-     * provided level.
-     *
-     * @param  int    $level
-     * @return string
-     */
-    protected function getAttachmentColor($level)
-    {
-        switch (true) {
-            case $level >= Logger::ERROR:
-                return 'danger';
-            case $level >= Logger::WARNING:
-                return 'warning';
-            case $level >= Logger::INFO:
-                return 'good';
-            default:
-                return '#e3e4e6';
-        }
-    }
-
-    /**
-     * Stringifies an array of key/value pairs to be used in attachment fields
-     *
-     * @param array $fields
-     * @access protected
-     * @return string
-     */
-    protected function stringify($fields)
-    {
-        $string = '';
-        foreach ($fields as $var => $val) {
-            $string .= $var.': '.$this->lineFormatter->stringify($val)." | ";
-        }
-
-        $string = rtrim($string, " |");
-
-        return $string;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/SocketHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/SocketHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/SocketHandler.php
deleted file mode 100644
index ee486f6..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/SocketHandler.php
+++ /dev/null
@@ -1,284 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Handler;
-
-use Monolog\Logger;
-
-/**
- * Stores to any socket - uses fsockopen() or pfsockopen().
- *
- * @author Pablo de Leon Belloc <pa...@gmail.com>
- * @see    http://php.net/manual/en/function.fsockopen.php
- */
-class SocketHandler extends AbstractProcessingHandler
-{
-    private $connectionString;
-    private $connectionTimeout;
-    private $resource;
-    private $timeout = 0;
-    private $persistent = false;
-    private $errno;
-    private $errstr;
-
-    /**
-     * @param string  $connectionString Socket connection string
-     * @param integer $level            The minimum logging level at which this handler will be triggered
-     * @param Boolean $bubble           Whether the messages that are handled can bubble up the stack or not
-     */
-    public function __construct($connectionString, $level = Logger::DEBUG, $bubble = true)
-    {
-        parent::__construct($level, $bubble);
-        $this->connectionString = $connectionString;
-        $this->connectionTimeout = (float) ini_get('default_socket_timeout');
-    }
-
-    /**
-     * Connect (if necessary) and write to the socket
-     *
-     * @param array $record
-     *
-     * @throws \UnexpectedValueException
-     * @throws \RuntimeException
-     */
-    protected function write(array $record)
-    {
-        $this->connectIfNotConnected();
-        $data = $this->generateDataStream($record);
-        $this->writeToSocket($data);
-    }
-
-    /**
-     * We will not close a PersistentSocket instance so it can be reused in other requests.
-     */
-    public function close()
-    {
-        if (!$this->isPersistent()) {
-            $this->closeSocket();
-        }
-    }
-
-    /**
-     * Close socket, if open
-     */
-    public function closeSocket()
-    {
-        if (is_resource($this->resource)) {
-            fclose($this->resource);
-            $this->resource = null;
-        }
-    }
-
-    /**
-     * Set socket connection to nbe persistent. It only has effect before the connection is initiated.
-     *
-     * @param type $boolean
-     */
-    public function setPersistent($boolean)
-    {
-        $this->persistent = (boolean) $boolean;
-    }
-
-    /**
-     * Set connection timeout.  Only has effect before we connect.
-     *
-     * @param float $seconds
-     *
-     * @see http://php.net/manual/en/function.fsockopen.php
-     */
-    public function setConnectionTimeout($seconds)
-    {
-        $this->validateTimeout($seconds);
-        $this->connectionTimeout = (float) $seconds;
-    }
-
-    /**
-     * Set write timeout. Only has effect before we connect.
-     *
-     * @param float $seconds
-     *
-     * @see http://php.net/manual/en/function.stream-set-timeout.php
-     */
-    public function setTimeout($seconds)
-    {
-        $this->validateTimeout($seconds);
-        $this->timeout = (float) $seconds;
-    }
-
-    /**
-     * Get current connection string
-     *
-     * @return string
-     */
-    public function getConnectionString()
-    {
-        return $this->connectionString;
-    }
-
-    /**
-     * Get persistent setting
-     *
-     * @return boolean
-     */
-    public function isPersistent()
-    {
-        return $this->persistent;
-    }
-
-    /**
-     * Get current connection timeout setting
-     *
-     * @return float
-     */
-    public function getConnectionTimeout()
-    {
-        return $this->connectionTimeout;
-    }
-
-    /**
-     * Get current in-transfer timeout
-     *
-     * @return float
-     */
-    public function getTimeout()
-    {
-        return $this->timeout;
-    }
-
-    /**
-     * Check to see if the socket is currently available.
-     *
-     * UDP might appear to be connected but might fail when writing.  See http://php.net/fsockopen for details.
-     *
-     * @return boolean
-     */
-    public function isConnected()
-    {
-        return is_resource($this->resource)
-            && !feof($this->resource);  // on TCP - other party can close connection.
-    }
-
-    /**
-     * Wrapper to allow mocking
-     */
-    protected function pfsockopen()
-    {
-        return @pfsockopen($this->connectionString, -1, $this->errno, $this->errstr, $this->connectionTimeout);
-    }
-
-    /**
-     * Wrapper to allow mocking
-     */
-    protected function fsockopen()
-    {
-        return @fsockopen($this->connectionString, -1, $this->errno, $this->errstr, $this->connectionTimeout);
-    }
-
-    /**
-     * Wrapper to allow mocking
-     *
-     * @see http://php.net/manual/en/function.stream-set-timeout.php
-     */
-    protected function streamSetTimeout()
-    {
-        $seconds = floor($this->timeout);
-        $microseconds = round(($this->timeout - $seconds)*1e6);
-
-        return stream_set_timeout($this->resource, $seconds, $microseconds);
-    }
-
-    /**
-     * Wrapper to allow mocking
-     */
-    protected function fwrite($data)
-    {
-        return @fwrite($this->resource, $data);
-    }
-
-    /**
-     * Wrapper to allow mocking
-     */
-    protected function streamGetMetadata()
-    {
-        return stream_get_meta_data($this->resource);
-    }
-
-    private function validateTimeout($value)
-    {
-        $ok = filter_var($value, FILTER_VALIDATE_FLOAT);
-        if ($ok === false || $value < 0) {
-            throw new \InvalidArgumentException("Timeout must be 0 or a positive float (got $value)");
-        }
-    }
-
-    private function connectIfNotConnected()
-    {
-        if ($this->isConnected()) {
-            return;
-        }
-        $this->connect();
-    }
-
-    protected function generateDataStream($record)
-    {
-        return (string) $record['formatted'];
-    }
-
-    private function connect()
-    {
-        $this->createSocketResource();
-        $this->setSocketTimeout();
-    }
-
-    private function createSocketResource()
-    {
-        if ($this->isPersistent()) {
-            $resource = $this->pfsockopen();
-        } else {
-            $resource = $this->fsockopen();
-        }
-        if (!$resource) {
-            throw new \UnexpectedValueException("Failed connecting to $this->connectionString ($this->errno: $this->errstr)");
-        }
-        $this->resource = $resource;
-    }
-
-    private function setSocketTimeout()
-    {
-        if (!$this->streamSetTimeout()) {
-            throw new \UnexpectedValueException("Failed setting timeout with stream_set_timeout()");
-        }
-    }
-
-    private function writeToSocket($data)
-    {
-        $length = strlen($data);
-        $sent = 0;
-        while ($this->isConnected() && $sent < $length) {
-            if (0 == $sent) {
-                $chunk = $this->fwrite($data);
-            } else {
-                $chunk = $this->fwrite(substr($data, $sent));
-            }
-            if ($chunk === false) {
-                throw new \RuntimeException("Could not write to socket");
-            }
-            $sent += $chunk;
-            $socketInfo = $this->streamGetMetadata();
-            if ($socketInfo['timed_out']) {
-                throw new \RuntimeException("Write timed-out");
-            }
-        }
-        if (!$this->isConnected() && $sent < $length) {
-            throw new \RuntimeException("End-of-file reached, probably we got disconnected (sent $sent of $length)");
-        }
-    }
-}