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:39:59 UTC

[19/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/StreamHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/StreamHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/StreamHandler.php
deleted file mode 100644
index 7965db7..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/StreamHandler.php
+++ /dev/null
@@ -1,104 +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 stream resource
- *
- * Can be used to store into php://stderr, remote and local files, etc.
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class StreamHandler extends AbstractProcessingHandler
-{
-    protected $stream;
-    protected $url;
-    private $errorMessage;
-    protected $filePermission;
-    protected $useLocking;
-
-    /**
-     * @param resource|string $stream
-     * @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
-     *
-     * @throws \InvalidArgumentException If stream is not a resource or string
-     */
-    public function __construct($stream, $level = Logger::DEBUG, $bubble = true, $filePermission = null, $useLocking = false)
-    {
-        parent::__construct($level, $bubble);
-        if (is_resource($stream)) {
-            $this->stream = $stream;
-        } elseif (is_string($stream)) {
-            $this->url = $stream;
-        } else {
-            throw new \InvalidArgumentException('A stream must either be a resource or a string.');
-        }
-
-        $this->filePermission = $filePermission;
-        $this->useLocking = $useLocking;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function close()
-    {
-        if (is_resource($this->stream)) {
-            fclose($this->stream);
-        }
-        $this->stream = null;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        if (!is_resource($this->stream)) {
-            if (!$this->url) {
-                throw new \LogicException('Missing stream url, the stream can not be opened. This may be caused by a premature call to close().');
-            }
-            $this->errorMessage = null;
-            set_error_handler(array($this, 'customErrorHandler'));
-            $this->stream = fopen($this->url, 'a');
-            if ($this->filePermission !== null) {
-                @chmod($this->url, $this->filePermission);
-            }
-            restore_error_handler();
-            if (!is_resource($this->stream)) {
-                $this->stream = null;
-                throw new \UnexpectedValueException(sprintf('The stream or file "%s" could not be opened: '.$this->errorMessage, $this->url));
-            }
-        }
-
-        if ($this->useLocking) {
-            // ignoring errors here, there's not much we can do about them
-            flock($this->stream, LOCK_EX);
-        }
-
-        fwrite($this->stream, (string) $record['formatted']);
-
-        if ($this->useLocking) {
-            flock($this->stream, LOCK_UN);
-        }
-    }
-
-    private function customErrorHandler($code, $msg)
-    {
-        $this->errorMessage = preg_replace('{^fopen\(.*?\): }', '', $msg);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/SwiftMailerHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/SwiftMailerHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/SwiftMailerHandler.php
deleted file mode 100644
index 003a1a2..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/SwiftMailerHandler.php
+++ /dev/null
@@ -1,87 +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;
-
-/**
- * SwiftMailerHandler uses Swift_Mailer to send the emails
- *
- * @author Gyula Sallai
- */
-class SwiftMailerHandler extends MailHandler
-{
-    protected $mailer;
-    private $messageTemplate;
-
-    /**
-     * @param \Swift_Mailer           $mailer  The mailer to use
-     * @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(\Swift_Mailer $mailer, $message, $level = Logger::ERROR, $bubble = true)
-    {
-        parent::__construct($level, $bubble);
-
-        $this->mailer = $mailer;
-        $this->messageTemplate = $message;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function send($content, array $records)
-    {
-        $this->mailer->send($this->buildMessage($content, $records));
-    }
-
-    /**
-     * Creates instance of Swift_Message to be sent
-     *
-     * @param string $content formatted email body to be sent
-     * @param array  $records Log records that formed the content
-     * @return \Swift_Message
-     */
-    protected function buildMessage($content, array $records)
-    {
-        $message = null;
-        if ($this->messageTemplate instanceof \Swift_Message) {
-            $message = clone $this->messageTemplate;
-        } else if (is_callable($this->messageTemplate)) {
-            $message = call_user_func($this->messageTemplate, $content, $records);
-        }
-
-        if (!$message instanceof \Swift_Message) {
-            throw new \InvalidArgumentException('Could not resolve message as instance of Swift_Message or a callable returning it');
-        }
-
-        $message->setBody($content);
-        $message->setDate(time());
-
-        return $message;
-    }
-
-    /**
-     * BC getter, to be removed in 2.0
-     */
-    public function __get($name)
-    {
-        if ($name === 'message') {
-            trigger_error('SwiftMailerHandler->message is deprecated, use ->buildMessage() instead to retrieve the message', E_USER_DEPRECATED);
-
-            return $this->buildMessage(null, array());
-        }
-
-        throw new \InvalidArgumentException('Invalid property '.$name);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/SyslogHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/SyslogHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/SyslogHandler.php
deleted file mode 100644
index 47c73e1..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/SyslogHandler.php
+++ /dev/null
@@ -1,67 +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;
-
-/**
- * Logs to syslog service.
- *
- * usage example:
- *
- *   $log = new Logger('application');
- *   $syslog = new SyslogHandler('myfacility', 'local6');
- *   $formatter = new LineFormatter("%channel%.%level_name%: %message% %extra%");
- *   $syslog->setFormatter($formatter);
- *   $log->pushHandler($syslog);
- *
- * @author Sven Paulus <sv...@karlsruhe.org>
- */
-class SyslogHandler extends AbstractSyslogHandler
-{
-    protected $ident;
-    protected $logopts;
-
-    /**
-     * @param string  $ident
-     * @param mixed   $facility
-     * @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     $logopts  Option flags for the openlog() call, defaults to LOG_PID
-     */
-    public function __construct($ident, $facility = LOG_USER, $level = Logger::DEBUG, $bubble = true, $logopts = LOG_PID)
-    {
-        parent::__construct($facility, $level, $bubble);
-
-        $this->ident = $ident;
-        $this->logopts = $logopts;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function close()
-    {
-        closelog();
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        if (!openlog($this->ident, $this->logopts, $this->facility)) {
-            throw new \LogicException('Can\'t open syslog for ident "'.$this->ident.'" and facility "'.$this->facility.'"');
-        }
-        syslog($this->logLevels[$record['level']], (string) $record['formatted']);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/SyslogUdp/UdpSocket.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/SyslogUdp/UdpSocket.php b/vendor/monolog/monolog/src/Monolog/Handler/SyslogUdp/UdpSocket.php
deleted file mode 100644
index dcf3f1f..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/SyslogUdp/UdpSocket.php
+++ /dev/null
@@ -1,46 +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\SyslogUdp;
-
-class UdpSocket
-{
-    const DATAGRAM_MAX_LENGTH = 65023;
-
-    public function __construct($ip, $port = 514)
-    {
-        $this->ip = $ip;
-        $this->port = $port;
-        $this->socket = socket_create(AF_INET, SOCK_DGRAM, SOL_UDP);
-    }
-
-    public function write($line, $header = "")
-    {
-        $this->send($this->assembleMessage($line, $header));
-    }
-
-    public function close()
-    {
-        socket_close($this->socket);
-    }
-
-    protected function send($chunk)
-    {
-        socket_sendto($this->socket, $chunk, strlen($chunk), $flags = 0, $this->ip, $this->port);
-    }
-
-    protected function assembleMessage($line, $header)
-    {
-        $chunkSize = self::DATAGRAM_MAX_LENGTH - strlen($header);
-
-        return $header . substr($line, 0, $chunkSize);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/SyslogUdpHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/SyslogUdpHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/SyslogUdpHandler.php
deleted file mode 100644
index aa047c0..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/SyslogUdpHandler.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;
-
-use Monolog\Logger;
-use Monolog\Handler\SyslogUdp\UdpSocket;
-
-/**
- * A Handler for logging to a remote syslogd server.
- *
- * @author Jesper Skovgaard Nielsen <nu...@gmail.com>
- */
-class SyslogUdpHandler extends AbstractSyslogHandler
-{
-    /**
-     * @param string  $host
-     * @param int     $port
-     * @param mixed   $facility
-     * @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($host, $port = 514, $facility = LOG_USER, $level = Logger::DEBUG, $bubble = true)
-    {
-        parent::__construct($facility, $level, $bubble);
-
-        $this->socket = new UdpSocket($host, $port ?: 514);
-    }
-
-    protected function write(array $record)
-    {
-        $lines = $this->splitMessageIntoLines($record['formatted']);
-
-        $header = $this->makeCommonSyslogHeader($this->logLevels[$record['level']]);
-
-        foreach ($lines as $line) {
-            $this->socket->write($line, $header);
-        }
-    }
-
-    public function close()
-    {
-        $this->socket->close();
-    }
-
-    private function splitMessageIntoLines($message)
-    {
-        if (is_array($message)) {
-            $message = implode("\n", $message);
-        }
-
-        return preg_split('/$\R?^/m', $message);
-    }
-
-    /**
-     * Make common syslog header (see rfc5424)
-     */
-    protected function makeCommonSyslogHeader($severity)
-    {
-        $priority = $severity + $this->facility;
-
-        return "<$priority>1 ";
-    }
-
-    /**
-     * Inject your own socket, mainly used for testing
-     */
-    public function setSocket($socket)
-    {
-        $this->socket = $socket;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/TestHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/TestHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/TestHandler.php
deleted file mode 100644
index 085d9e1..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/TestHandler.php
+++ /dev/null
@@ -1,140 +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;
-
-/**
- * Used for testing purposes.
- *
- * It records all records and gives you access to them for verification.
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class TestHandler extends AbstractProcessingHandler
-{
-    protected $records = array();
-    protected $recordsByLevel = array();
-
-    public function getRecords()
-    {
-        return $this->records;
-    }
-
-    public function hasEmergency($record)
-    {
-        return $this->hasRecord($record, Logger::EMERGENCY);
-    }
-
-    public function hasAlert($record)
-    {
-        return $this->hasRecord($record, Logger::ALERT);
-    }
-
-    public function hasCritical($record)
-    {
-        return $this->hasRecord($record, Logger::CRITICAL);
-    }
-
-    public function hasError($record)
-    {
-        return $this->hasRecord($record, Logger::ERROR);
-    }
-
-    public function hasWarning($record)
-    {
-        return $this->hasRecord($record, Logger::WARNING);
-    }
-
-    public function hasNotice($record)
-    {
-        return $this->hasRecord($record, Logger::NOTICE);
-    }
-
-    public function hasInfo($record)
-    {
-        return $this->hasRecord($record, Logger::INFO);
-    }
-
-    public function hasDebug($record)
-    {
-        return $this->hasRecord($record, Logger::DEBUG);
-    }
-
-    public function hasEmergencyRecords()
-    {
-        return isset($this->recordsByLevel[Logger::EMERGENCY]);
-    }
-
-    public function hasAlertRecords()
-    {
-        return isset($this->recordsByLevel[Logger::ALERT]);
-    }
-
-    public function hasCriticalRecords()
-    {
-        return isset($this->recordsByLevel[Logger::CRITICAL]);
-    }
-
-    public function hasErrorRecords()
-    {
-        return isset($this->recordsByLevel[Logger::ERROR]);
-    }
-
-    public function hasWarningRecords()
-    {
-        return isset($this->recordsByLevel[Logger::WARNING]);
-    }
-
-    public function hasNoticeRecords()
-    {
-        return isset($this->recordsByLevel[Logger::NOTICE]);
-    }
-
-    public function hasInfoRecords()
-    {
-        return isset($this->recordsByLevel[Logger::INFO]);
-    }
-
-    public function hasDebugRecords()
-    {
-        return isset($this->recordsByLevel[Logger::DEBUG]);
-    }
-
-    protected function hasRecord($record, $level)
-    {
-        if (!isset($this->recordsByLevel[$level])) {
-            return false;
-        }
-
-        if (is_array($record)) {
-            $record = $record['message'];
-        }
-
-        foreach ($this->recordsByLevel[$level] as $rec) {
-            if ($rec['message'] === $record) {
-                return true;
-            }
-        }
-
-        return false;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        $this->recordsByLevel[$record['level']][] = $record;
-        $this->records[] = $record;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/WhatFailureGroupHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/WhatFailureGroupHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/WhatFailureGroupHandler.php
deleted file mode 100644
index 05a8817..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/WhatFailureGroupHandler.php
+++ /dev/null
@@ -1,57 +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 suppressing failures of each handler
- * and continuing through to give every handler a chance to succeed.
- *
- * @author Craig D'Amelio <cr...@damelio.ca>
- */
-class WhatFailureGroupHandler extends GroupHandler
-{
-    /**
-     * {@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) {
-            try {
-                $handler->handle($record);
-            } catch (\Exception $e) {
-                // What failure?
-            }
-        }
-
-        return false === $this->bubble;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function handleBatch(array $records)
-    {
-        foreach ($this->handlers as $handler) {
-            try {
-                $handler->handleBatch($records);
-            } catch (\Exception $e) {
-                // What failure?
-            }
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Handler/ZendMonitorHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Handler/ZendMonitorHandler.php b/vendor/monolog/monolog/src/Monolog/Handler/ZendMonitorHandler.php
deleted file mode 100644
index f22cf21..0000000
--- a/vendor/monolog/monolog/src/Monolog/Handler/ZendMonitorHandler.php
+++ /dev/null
@@ -1,95 +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\NormalizerFormatter;
-use Monolog\Logger;
-
-/**
- * Handler sending logs to Zend Monitor
- *
- * @author  Christian Bergau <cb...@gmail.com>
- */
-class ZendMonitorHandler extends AbstractProcessingHandler
-{
-    /**
-     * Monolog level / ZendMonitor Custom Event priority map
-     *
-     * @var array
-     */
-    protected $levelMap = array(
-        Logger::DEBUG     => 1,
-        Logger::INFO      => 2,
-        Logger::NOTICE    => 3,
-        Logger::WARNING   => 4,
-        Logger::ERROR     => 5,
-        Logger::CRITICAL  => 6,
-        Logger::ALERT     => 7,
-        Logger::EMERGENCY => 0,
-    );
-
-    /**
-     * Construct
-     *
-     * @param  int                       $level
-     * @param  bool                      $bubble
-     * @throws MissingExtensionException
-     */
-    public function __construct($level = Logger::DEBUG, $bubble = true)
-    {
-        if (!function_exists('zend_monitor_custom_event')) {
-            throw new MissingExtensionException('You must have Zend Server installed in order to use this handler');
-        }
-        parent::__construct($level, $bubble);
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    protected function write(array $record)
-    {
-        $this->writeZendMonitorCustomEvent(
-            $this->levelMap[$record['level']],
-            $record['message'],
-            $record['formatted']
-        );
-    }
-
-    /**
-     * Write a record to Zend Monitor
-     *
-     * @param int    $level
-     * @param string $message
-     * @param array  $formatted
-     */
-    protected function writeZendMonitorCustomEvent($level, $message, $formatted)
-    {
-        zend_monitor_custom_event($level, $message, $formatted);
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function getDefaultFormatter()
-    {
-        return new NormalizerFormatter();
-    }
-
-    /**
-     * Get the level map
-     *
-     * @return array
-     */
-    public function getLevelMap()
-    {
-        return $this->levelMap;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Logger.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Logger.php b/vendor/monolog/monolog/src/Monolog/Logger.php
deleted file mode 100644
index 4a38de7..0000000
--- a/vendor/monolog/monolog/src/Monolog/Logger.php
+++ /dev/null
@@ -1,615 +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;
-
-use Monolog\Handler\HandlerInterface;
-use Monolog\Handler\StreamHandler;
-use Psr\Log\LoggerInterface;
-use Psr\Log\InvalidArgumentException;
-
-/**
- * Monolog log channel
- *
- * It contains a stack of Handlers and a stack of Processors,
- * and uses them to store records that are added to it.
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class Logger implements LoggerInterface
-{
-    /**
-     * Detailed debug information
-     */
-    const DEBUG = 100;
-
-    /**
-     * Interesting events
-     *
-     * Examples: User logs in, SQL logs.
-     */
-    const INFO = 200;
-
-    /**
-     * Uncommon events
-     */
-    const NOTICE = 250;
-
-    /**
-     * Exceptional occurrences that are not errors
-     *
-     * Examples: Use of deprecated APIs, poor use of an API,
-     * undesirable things that are not necessarily wrong.
-     */
-    const WARNING = 300;
-
-    /**
-     * Runtime errors
-     */
-    const ERROR = 400;
-
-    /**
-     * Critical conditions
-     *
-     * Example: Application component unavailable, unexpected exception.
-     */
-    const CRITICAL = 500;
-
-    /**
-     * Action must be taken immediately
-     *
-     * Example: Entire website down, database unavailable, etc.
-     * This should trigger the SMS alerts and wake you up.
-     */
-    const ALERT = 550;
-
-    /**
-     * Urgent alert.
-     */
-    const EMERGENCY = 600;
-
-    /**
-     * Monolog API version
-     *
-     * This is only bumped when API breaks are done and should
-     * follow the major version of the library
-     *
-     * @var int
-     */
-    const API = 1;
-
-    /**
-     * Logging levels from syslog protocol defined in RFC 5424
-     *
-     * @var array $levels Logging levels
-     */
-    protected static $levels = array(
-        100 => 'DEBUG',
-        200 => 'INFO',
-        250 => 'NOTICE',
-        300 => 'WARNING',
-        400 => 'ERROR',
-        500 => 'CRITICAL',
-        550 => 'ALERT',
-        600 => 'EMERGENCY',
-    );
-
-    /**
-     * @var \DateTimeZone
-     */
-    protected static $timezone;
-
-    /**
-     * @var string
-     */
-    protected $name;
-
-    /**
-     * The handler stack
-     *
-     * @var HandlerInterface[]
-     */
-    protected $handlers;
-
-    /**
-     * Processors that will process all log records
-     *
-     * To process records of a single handler instead, add the processor on that specific handler
-     *
-     * @var callable[]
-     */
-    protected $processors;
-
-    /**
-     * @param string             $name       The logging channel
-     * @param HandlerInterface[] $handlers   Optional stack of handlers, the first one in the array is called first, etc.
-     * @param callable[]         $processors Optional array of processors
-     */
-    public function __construct($name, array $handlers = array(), array $processors = array())
-    {
-        $this->name = $name;
-        $this->handlers = $handlers;
-        $this->processors = $processors;
-    }
-
-    /**
-     * @return string
-     */
-    public function getName()
-    {
-        return $this->name;
-    }
-
-    /**
-     * Pushes a handler on to the stack.
-     *
-     * @param HandlerInterface $handler
-     */
-    public function pushHandler(HandlerInterface $handler)
-    {
-        array_unshift($this->handlers, $handler);
-    }
-
-    /**
-     * Pops a handler from the stack
-     *
-     * @return HandlerInterface
-     */
-    public function popHandler()
-    {
-        if (!$this->handlers) {
-            throw new \LogicException('You tried to pop from an empty handler stack.');
-        }
-
-        return array_shift($this->handlers);
-    }
-
-    /**
-     * @return HandlerInterface[]
-     */
-    public function getHandlers()
-    {
-        return $this->handlers;
-    }
-
-    /**
-     * Adds a processor on to the stack.
-     *
-     * @param callable $callback
-     */
-    public function pushProcessor($callback)
-    {
-        if (!is_callable($callback)) {
-            throw new \InvalidArgumentException('Processors must be valid callables (callback or object with an __invoke method), '.var_export($callback, true).' given');
-        }
-        array_unshift($this->processors, $callback);
-    }
-
-    /**
-     * Removes the processor on top of the stack and returns it.
-     *
-     * @return callable
-     */
-    public function popProcessor()
-    {
-        if (!$this->processors) {
-            throw new \LogicException('You tried to pop from an empty processor stack.');
-        }
-
-        return array_shift($this->processors);
-    }
-
-    /**
-     * @return callable[]
-     */
-    public function getProcessors()
-    {
-        return $this->processors;
-    }
-
-    /**
-     * Adds a log record.
-     *
-     * @param  integer $level   The logging level
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addRecord($level, $message, array $context = array())
-    {
-        if (!$this->handlers) {
-            $this->pushHandler(new StreamHandler('php://stderr', static::DEBUG));
-        }
-
-        $levelName = static::getLevelName($level);
-
-        // check if any handler will handle this message so we can return early and save cycles
-        $handlerKey = null;
-        foreach ($this->handlers as $key => $handler) {
-            if ($handler->isHandling(array('level' => $level))) {
-                $handlerKey = $key;
-                break;
-            }
-        }
-
-        if (null === $handlerKey) {
-            return false;
-        }
-
-        if (!static::$timezone) {
-            static::$timezone = new \DateTimeZone(date_default_timezone_get() ?: 'UTC');
-        }
-
-        $record = array(
-            'message' => (string) $message,
-            'context' => $context,
-            'level' => $level,
-            'level_name' => $levelName,
-            'channel' => $this->name,
-            'datetime' => \DateTime::createFromFormat('U.u', sprintf('%.6F', microtime(true)), static::$timezone)->setTimezone(static::$timezone),
-            'extra' => array(),
-        );
-
-        foreach ($this->processors as $processor) {
-            $record = call_user_func($processor, $record);
-        }
-        while (isset($this->handlers[$handlerKey]) &&
-            false === $this->handlers[$handlerKey]->handle($record)) {
-            $handlerKey++;
-        }
-
-        return true;
-    }
-
-    /**
-     * Adds a log record at the DEBUG level.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addDebug($message, array $context = array())
-    {
-        return $this->addRecord(static::DEBUG, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the INFO level.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addInfo($message, array $context = array())
-    {
-        return $this->addRecord(static::INFO, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the NOTICE level.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addNotice($message, array $context = array())
-    {
-        return $this->addRecord(static::NOTICE, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the WARNING level.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addWarning($message, array $context = array())
-    {
-        return $this->addRecord(static::WARNING, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the ERROR level.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addError($message, array $context = array())
-    {
-        return $this->addRecord(static::ERROR, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the CRITICAL level.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addCritical($message, array $context = array())
-    {
-        return $this->addRecord(static::CRITICAL, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the ALERT level.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addAlert($message, array $context = array())
-    {
-        return $this->addRecord(static::ALERT, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the EMERGENCY level.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function addEmergency($message, array $context = array())
-    {
-        return $this->addRecord(static::EMERGENCY, $message, $context);
-    }
-
-    /**
-     * Gets all supported logging levels.
-     *
-     * @return array Assoc array with human-readable level names => level codes.
-     */
-    public static function getLevels()
-    {
-        return array_flip(static::$levels);
-    }
-
-    /**
-     * Gets the name of the logging level.
-     *
-     * @param  integer $level
-     * @return string
-     */
-    public static function getLevelName($level)
-    {
-        if (!isset(static::$levels[$level])) {
-            throw new InvalidArgumentException('Level "'.$level.'" is not defined, use one of: '.implode(', ', array_keys(static::$levels)));
-        }
-
-        return static::$levels[$level];
-    }
-
-    /**
-     * Converts PSR-3 levels to Monolog ones if necessary
-     *
-     * @param string|int Level number (monolog) or name (PSR-3)
-     * @return int
-     */
-    public static function toMonologLevel($level)
-    {
-        if (is_string($level) && defined(__CLASS__.'::'.strtoupper($level))) {
-            return constant(__CLASS__.'::'.strtoupper($level));
-        }
-
-        return $level;
-    }
-
-    /**
-     * Checks whether the Logger has a handler that listens on the given level
-     *
-     * @param  integer $level
-     * @return Boolean
-     */
-    public function isHandling($level)
-    {
-        $record = array(
-            'level' => $level,
-        );
-
-        foreach ($this->handlers as $handler) {
-            if ($handler->isHandling($record)) {
-                return true;
-            }
-        }
-
-        return false;
-    }
-
-    /**
-     * Adds a log record at an arbitrary level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  mixed   $level   The log level
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function log($level, $message, array $context = array())
-    {
-        if (is_string($level) && defined(__CLASS__.'::'.strtoupper($level))) {
-            $level = constant(__CLASS__.'::'.strtoupper($level));
-        }
-
-        return $this->addRecord($level, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the DEBUG level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function debug($message, array $context = array())
-    {
-        return $this->addRecord(static::DEBUG, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the INFO level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function info($message, array $context = array())
-    {
-        return $this->addRecord(static::INFO, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the NOTICE level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function notice($message, array $context = array())
-    {
-        return $this->addRecord(static::NOTICE, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the WARNING level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function warn($message, array $context = array())
-    {
-        return $this->addRecord(static::WARNING, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the WARNING level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function warning($message, array $context = array())
-    {
-        return $this->addRecord(static::WARNING, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the ERROR level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function err($message, array $context = array())
-    {
-        return $this->addRecord(static::ERROR, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the ERROR level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function error($message, array $context = array())
-    {
-        return $this->addRecord(static::ERROR, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the CRITICAL level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function crit($message, array $context = array())
-    {
-        return $this->addRecord(static::CRITICAL, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the CRITICAL level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function critical($message, array $context = array())
-    {
-        return $this->addRecord(static::CRITICAL, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the ALERT level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function alert($message, array $context = array())
-    {
-        return $this->addRecord(static::ALERT, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the EMERGENCY level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function emerg($message, array $context = array())
-    {
-        return $this->addRecord(static::EMERGENCY, $message, $context);
-    }
-
-    /**
-     * Adds a log record at the EMERGENCY level.
-     *
-     * This method allows for compatibility with common interfaces.
-     *
-     * @param  string  $message The log message
-     * @param  array   $context The log context
-     * @return Boolean Whether the record has been processed
-     */
-    public function emergency($message, array $context = array())
-    {
-        return $this->addRecord(static::EMERGENCY, $message, $context);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/GitProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/GitProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/GitProcessor.php
deleted file mode 100644
index 1899400..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/GitProcessor.php
+++ /dev/null
@@ -1,64 +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\Processor;
-
-use Monolog\Logger;
-
-/**
- * Injects Git branch and Git commit SHA in all records
- *
- * @author Nick Otter
- * @author Jordi Boggiano <j....@seld.be>
- */
-class GitProcessor
-{
-    private $level;
-    private static $cache;
-
-    public function __construct($level = Logger::DEBUG)
-    {
-        $this->level = Logger::toMonologLevel($level);
-    }
-
-    /**
-     * @param  array $record
-     * @return array
-     */
-    public function __invoke(array $record)
-    {
-        // return if the level is not high enough
-        if ($record['level'] < $this->level) {
-            return $record;
-        }
-
-        $record['extra']['git'] = self::getGitInfo();
-
-        return $record;
-    }
-
-    private static function getGitInfo()
-    {
-        if (self::$cache) {
-            return self::$cache;
-        }
-
-        $branches = `git branch -v --no-abbrev`;
-        if (preg_match('{^\* (.+?)\s+([a-f0-9]{40})(?:\s|$)}m', $branches, $matches)) {
-            return self::$cache = array(
-                'branch' => $matches[1],
-                'commit' => $matches[2],
-            );
-        }
-
-        return self::$cache = array();
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/IntrospectionProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/IntrospectionProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/IntrospectionProcessor.php
deleted file mode 100644
index 294a295..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/IntrospectionProcessor.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\Processor;
-
-use Monolog\Logger;
-
-/**
- * Injects line/file:class/function where the log message came from
- *
- * Warning: This only works if the handler processes the logs directly.
- * If you put the processor on a handler that is behind a FingersCrossedHandler
- * for example, the processor will only be called once the trigger level is reached,
- * and all the log records will have the same file/line/.. data from the call that
- * triggered the FingersCrossedHandler.
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class IntrospectionProcessor
-{
-    private $level;
-
-    private $skipClassesPartials;
-
-    public function __construct($level = Logger::DEBUG, array $skipClassesPartials = array('Monolog\\'))
-    {
-        $this->level = Logger::toMonologLevel($level);
-        $this->skipClassesPartials = $skipClassesPartials;
-    }
-
-    /**
-     * @param  array $record
-     * @return array
-     */
-    public function __invoke(array $record)
-    {
-        // return if the level is not high enough
-        if ($record['level'] < $this->level) {
-            return $record;
-        }
-
-        $trace = debug_backtrace();
-
-        // skip first since it's always the current method
-        array_shift($trace);
-        // the call_user_func call is also skipped
-        array_shift($trace);
-
-        $i = 0;
-
-        while (isset($trace[$i]['class'])) {
-            foreach ($this->skipClassesPartials as $part) {
-                if (strpos($trace[$i]['class'], $part) !== false) {
-                    $i++;
-                    continue 2;
-                }
-            }
-            break;
-        }
-
-        // we should have the call source now
-        $record['extra'] = array_merge(
-            $record['extra'],
-            array(
-                'file'      => isset($trace[$i-1]['file']) ? $trace[$i-1]['file'] : null,
-                'line'      => isset($trace[$i-1]['line']) ? $trace[$i-1]['line'] : null,
-                'class'     => isset($trace[$i]['class']) ? $trace[$i]['class'] : null,
-                'function'  => isset($trace[$i]['function']) ? $trace[$i]['function'] : null,
-            )
-        );
-
-        return $record;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/MemoryPeakUsageProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/MemoryPeakUsageProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/MemoryPeakUsageProcessor.php
deleted file mode 100644
index 552fd70..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/MemoryPeakUsageProcessor.php
+++ /dev/null
@@ -1,40 +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\Processor;
-
-/**
- * Injects memory_get_peak_usage in all records
- *
- * @see Monolog\Processor\MemoryProcessor::__construct() for options
- * @author Rob Jensen
- */
-class MemoryPeakUsageProcessor extends MemoryProcessor
-{
-    /**
-     * @param  array $record
-     * @return array
-     */
-    public function __invoke(array $record)
-    {
-        $bytes = memory_get_peak_usage($this->realUsage);
-        $formatted = $this->formatBytes($bytes);
-
-        $record['extra'] = array_merge(
-            $record['extra'],
-            array(
-                'memory_peak_usage' => $formatted,
-            )
-        );
-
-        return $record;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/MemoryProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/MemoryProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/MemoryProcessor.php
deleted file mode 100644
index 0820def..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/MemoryProcessor.php
+++ /dev/null
@@ -1,63 +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\Processor;
-
-/**
- * Some methods that are common for all memory processors
- *
- * @author Rob Jensen
- */
-abstract class MemoryProcessor
-{
-    /**
-     * @var boolean If true, get the real size of memory allocated from system. Else, only the memory used by emalloc() is reported.
-     */
-    protected $realUsage;
-
-    /**
-     * @var boolean If true, then format memory size to human readable string (MB, KB, B depending on size)
-     */
-    protected $useFormatting;
-
-    /**
-     * @param boolean $realUsage     Set this to true to get the real size of memory allocated from system.
-     * @param boolean $useFormatting If true, then format memory size to human readable string (MB, KB, B depending on size)
-     */
-    public function __construct($realUsage = true, $useFormatting = true)
-    {
-        $this->realUsage = (boolean) $realUsage;
-        $this->useFormatting = (boolean) $useFormatting;
-    }
-
-    /**
-     * Formats bytes into a human readable string if $this->useFormatting is true, otherwise return $bytes as is
-     *
-     * @param  int        $bytes
-     * @return string|int Formatted string if $this->useFormatting is true, otherwise return $bytes as is
-     */
-    protected function formatBytes($bytes)
-    {
-        $bytes = (int) $bytes;
-
-        if (!$this->useFormatting) {
-            return $bytes;
-        }
-
-        if ($bytes > 1024*1024) {
-            return round($bytes/1024/1024, 2).' MB';
-        } elseif ($bytes > 1024) {
-            return round($bytes/1024, 2).' KB';
-        }
-
-        return $bytes . ' B';
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/MemoryUsageProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/MemoryUsageProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/MemoryUsageProcessor.php
deleted file mode 100644
index 0c4dd9a..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/MemoryUsageProcessor.php
+++ /dev/null
@@ -1,40 +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\Processor;
-
-/**
- * Injects memory_get_usage in all records
- *
- * @see Monolog\Processor\MemoryProcessor::__construct() for options
- * @author Rob Jensen
- */
-class MemoryUsageProcessor extends MemoryProcessor
-{
-    /**
-     * @param  array $record
-     * @return array
-     */
-    public function __invoke(array $record)
-    {
-        $bytes = memory_get_usage($this->realUsage);
-        $formatted = $this->formatBytes($bytes);
-
-        $record['extra'] = array_merge(
-            $record['extra'],
-            array(
-                'memory_usage' => $formatted,
-            )
-        );
-
-        return $record;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/ProcessIdProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/ProcessIdProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/ProcessIdProcessor.php
deleted file mode 100644
index 9d3f559..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/ProcessIdProcessor.php
+++ /dev/null
@@ -1,31 +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\Processor;
-
-/**
- * Adds value of getmypid into records
- *
- * @author Andreas Hörnicke
- */
-class ProcessIdProcessor
-{
-    /**
-     * @param  array $record
-     * @return array
-     */
-    public function __invoke(array $record)
-    {
-        $record['extra']['process_id'] = getmypid();
-
-        return $record;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/PsrLogMessageProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/PsrLogMessageProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/PsrLogMessageProcessor.php
deleted file mode 100644
index c2686ce..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/PsrLogMessageProcessor.php
+++ /dev/null
@@ -1,48 +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\Processor;
-
-/**
- * Processes a record's message according to PSR-3 rules
- *
- * It replaces {foo} with the value from $context['foo']
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class PsrLogMessageProcessor
-{
-    /**
-     * @param  array $record
-     * @return array
-     */
-    public function __invoke(array $record)
-    {
-        if (false === strpos($record['message'], '{')) {
-            return $record;
-        }
-
-        $replacements = array();
-        foreach ($record['context'] as $key => $val) {
-            if (is_null($val) || is_scalar($val) || (is_object($val) && method_exists($val, "__toString"))) {
-                $replacements['{'.$key.'}'] = $val;
-            } elseif (is_object($val)) {
-                $replacements['{'.$key.'}'] = '[object '.get_class($val).']';
-            } else {
-                $replacements['{'.$key.'}'] = '['.gettype($val).']';
-            }
-        }
-
-        $record['message'] = strtr($record['message'], $replacements);
-
-        return $record;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/TagProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/TagProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/TagProcessor.php
deleted file mode 100644
index 2784cef..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/TagProcessor.php
+++ /dev/null
@@ -1,34 +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\Processor;
-
-/**
- * Adds a tags array into record
- *
- * @author Martijn Riemers
- */
-class TagProcessor
-{
-    private $tags;
-
-    public function __construct(array $tags = array())
-    {
-        $this->tags = $tags;
-    }
-
-    public function __invoke(array $record)
-    {
-        $record['extra']['tags'] = $this->tags;
-
-        return $record;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/UidProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/UidProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/UidProcessor.php
deleted file mode 100644
index 80270d0..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/UidProcessor.php
+++ /dev/null
@@ -1,38 +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\Processor;
-
-/**
- * Adds a unique identifier into records
- *
- * @author Simon Mönch <sm...@webfactory.de>
- */
-class UidProcessor
-{
-    private $uid;
-
-    public function __construct($length = 7)
-    {
-        if (!is_int($length) || $length > 32 || $length < 1) {
-            throw new \InvalidArgumentException('The uid length must be an integer between 1 and 32');
-        }
-
-        $this->uid = substr(hash('md5', uniqid('', true)), 0, $length);
-    }
-
-    public function __invoke(array $record)
-    {
-        $record['extra']['uid'] = $this->uid;
-
-        return $record;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Processor/WebProcessor.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Processor/WebProcessor.php b/vendor/monolog/monolog/src/Monolog/Processor/WebProcessor.php
deleted file mode 100644
index 21f22a6..0000000
--- a/vendor/monolog/monolog/src/Monolog/Processor/WebProcessor.php
+++ /dev/null
@@ -1,105 +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\Processor;
-
-/**
- * Injects url/method and remote IP of the current web request in all records
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class WebProcessor
-{
-    /**
-     * @var array|\ArrayAccess
-     */
-    protected $serverData;
-
-    /**
-     * @var array
-     */
-    protected $extraFields = array(
-        'url'         => 'REQUEST_URI',
-        'ip'          => 'REMOTE_ADDR',
-        'http_method' => 'REQUEST_METHOD',
-        'server'      => 'SERVER_NAME',
-        'referrer'    => 'HTTP_REFERER',
-    );
-
-    /**
-     * @param array|\ArrayAccess $serverData  Array or object w/ ArrayAccess that provides access to the $_SERVER data
-     * @param array|null         $extraFields Extra field names to be added (all available by default)
-     */
-    public function __construct($serverData = null, array $extraFields = null)
-    {
-        if (null === $serverData) {
-            $this->serverData = &$_SERVER;
-        } elseif (is_array($serverData) || $serverData instanceof \ArrayAccess) {
-            $this->serverData = $serverData;
-        } else {
-            throw new \UnexpectedValueException('$serverData must be an array or object implementing ArrayAccess.');
-        }
-
-        if (null !== $extraFields) {
-            foreach (array_keys($this->extraFields) as $fieldName) {
-                if (!in_array($fieldName, $extraFields)) {
-                    unset($this->extraFields[$fieldName]);
-                }
-            }
-        }
-    }
-
-    /**
-     * @param  array $record
-     * @return array
-     */
-    public function __invoke(array $record)
-    {
-        // skip processing if for some reason request data
-        // is not present (CLI or wonky SAPIs)
-        if (!isset($this->serverData['REQUEST_URI'])) {
-            return $record;
-        }
-
-        $record['extra'] = $this->appendExtraFields($record['extra']);
-
-        return $record;
-    }
-
-    /**
-     * @param  string $extraName
-     * @param  string $serverName
-     * @return $this
-     */
-    public function addExtraField($extraName, $serverName)
-    {
-        $this->extraFields[$extraName] = $serverName;
-
-        return $this;
-    }
-
-    /**
-     * @param  array $extra
-     * @return array
-     */
-    private function appendExtraFields(array $extra)
-    {
-        foreach ($this->extraFields as $extraName => $serverName) {
-            $extra[$extraName] = isset($this->serverData[$serverName]) ? $this->serverData[$serverName] : null;
-        }
-
-        if (isset($this->serverData['UNIQUE_ID'])) {
-            $extra['unique_id'] = $this->serverData['UNIQUE_ID'];
-        }
-
-        return $extra;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Registry.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Registry.php b/vendor/monolog/monolog/src/Monolog/Registry.php
deleted file mode 100644
index 923b774..0000000
--- a/vendor/monolog/monolog/src/Monolog/Registry.php
+++ /dev/null
@@ -1,134 +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;
-
-use InvalidArgumentException;
-
-/**
- * Monolog log registry
- *
- * Allows to get `Logger` instances in the global scope
- * via static method calls on this class.
- *
- * <code>
- * $application = new Monolog\Logger('application');
- * $api = new Monolog\Logger('api');
- *
- * Monolog\Registry::addLogger($application);
- * Monolog\Registry::addLogger($api);
- *
- * function testLogger()
- * {
- *     Monolog\Registry::api()->addError('Sent to $api Logger instance');
- *     Monolog\Registry::application()->addError('Sent to $application Logger instance');
- * }
- * </code>
- *
- * @author Tomas Tatarko <to...@tatarko.sk>
- */
-class Registry
-{
-    /**
-     * List of all loggers in the registry (ba named indexes)
-     *
-     * @var Logger[]
-     */
-    private static $loggers = array();
-
-    /**
-     * Adds new logging channel to the registry
-     *
-     * @param  Logger                    $logger    Instance of the logging channel
-     * @param  string|null               $name      Name of the logging channel ($logger->getName() by default)
-     * @param  boolean                   $overwrite Overwrite instance in the registry if the given name already exists?
-     * @throws \InvalidArgumentException If $overwrite set to false and named Logger instance already exists
-     */
-    public static function addLogger(Logger $logger, $name = null, $overwrite = false)
-    {
-        $name = $name ?: $logger->getName();
-
-        if (isset(self::$loggers[$name]) && !$overwrite) {
-            throw new InvalidArgumentException('Logger with the given name already exists');
-        }
-
-        self::$loggers[$name] = $logger;
-    }
-
-    /**
-     * Checks if such logging channel exists by name or instance
-     *
-     * @param string|Logger $logger Name or logger instance
-     */
-    public static function hasLogger($logger)
-    {
-        if ($logger instanceof Logger) {
-            $index = array_search($logger, self::$loggers, true);
-
-            return false !== $index;
-        } else {
-            return isset(self::$loggers[$logger]);
-        }
-    }
-
-    /**
-     * Removes instance from registry by name or instance
-     *
-     * @param string|Logger $logger Name or logger instance
-     */
-    public static function removeLogger($logger)
-    {
-        if ($logger instanceof Logger) {
-            if (false !== ($idx = array_search($logger, self::$loggers, true))) {
-                unset(self::$loggers[$idx]);
-            }
-        } else {
-            unset(self::$loggers[$logger]);
-        }
-    }
-
-    /**
-     * Clears the registry
-     */
-    public static function clear()
-    {
-        self::$loggers = array();
-    }
-
-    /**
-     * Gets Logger instance from the registry
-     *
-     * @param  string                    $name Name of the requested Logger instance
-     * @return Logger                    Requested instance of Logger
-     * @throws \InvalidArgumentException If named Logger instance is not in the registry
-     */
-    public static function getInstance($name)
-    {
-        if (!isset(self::$loggers[$name])) {
-            throw new InvalidArgumentException(sprintf('Requested "%s" logger instance is not in the registry', $name));
-        }
-
-        return self::$loggers[$name];
-    }
-
-    /**
-     * Gets Logger instance from the registry via static method call
-     *
-     * @param  string                    $name      Name of the requested Logger instance
-     * @param  array                     $arguments Arguments passed to static method call
-     * @return Logger                    Requested instance of Logger
-     * @throws \InvalidArgumentException If named Logger instance is not in the registry
-     */
-    public static function __callStatic($name, $arguments)
-    {
-        return self::getInstance($name);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/tests/Monolog/ErrorHandlerTest.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/tests/Monolog/ErrorHandlerTest.php b/vendor/monolog/monolog/tests/Monolog/ErrorHandlerTest.php
deleted file mode 100644
index a9a3f30..0000000
--- a/vendor/monolog/monolog/tests/Monolog/ErrorHandlerTest.php
+++ /dev/null
@@ -1,31 +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;
-
-use Monolog\Handler\TestHandler;
-
-class ErrorHandlerTest extends \PHPUnit_Framework_TestCase
-{
-    public function testHandleError()
-    {
-        $logger = new Logger('test', array($handler = new TestHandler));
-        $errHandler = new ErrorHandler($logger);
-
-        $errHandler->registerErrorHandler(array(E_USER_NOTICE => Logger::EMERGENCY), false);
-        trigger_error('Foo', E_USER_ERROR);
-        $this->assertCount(1, $handler->getRecords());
-        $this->assertTrue($handler->hasErrorRecords());
-        trigger_error('Foo', E_USER_NOTICE);
-        $this->assertCount(2, $handler->getRecords());
-        $this->assertTrue($handler->hasEmergencyRecords());
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/tests/Monolog/Formatter/ChromePHPFormatterTest.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/tests/Monolog/Formatter/ChromePHPFormatterTest.php b/vendor/monolog/monolog/tests/Monolog/Formatter/ChromePHPFormatterTest.php
deleted file mode 100644
index e7f7334..0000000
--- a/vendor/monolog/monolog/tests/Monolog/Formatter/ChromePHPFormatterTest.php
+++ /dev/null
@@ -1,158 +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\Formatter;
-
-use Monolog\Logger;
-
-class ChromePHPFormatterTest extends \PHPUnit_Framework_TestCase
-{
-    /**
-     * @covers Monolog\Formatter\ChromePHPFormatter::format
-     */
-    public function testDefaultFormat()
-    {
-        $formatter = new ChromePHPFormatter();
-        $record = array(
-            'level' => Logger::ERROR,
-            'level_name' => 'ERROR',
-            'channel' => 'meh',
-            'context' => array('from' => 'logger'),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array('ip' => '127.0.0.1'),
-            'message' => 'log',
-        );
-
-        $message = $formatter->format($record);
-
-        $this->assertEquals(
-            array(
-                'meh',
-                array(
-                    'message' => 'log',
-                    'context' => array('from' => 'logger'),
-                    'extra' => array('ip' => '127.0.0.1'),
-                ),
-                'unknown',
-                'error'
-            ),
-            $message
-        );
-    }
-
-    /**
-     * @covers Monolog\Formatter\ChromePHPFormatter::format
-     */
-    public function testFormatWithFileAndLine()
-    {
-        $formatter = new ChromePHPFormatter();
-        $record = array(
-            'level' => Logger::CRITICAL,
-            'level_name' => 'CRITICAL',
-            'channel' => 'meh',
-            'context' => array('from' => 'logger'),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array('ip' => '127.0.0.1', 'file' => 'test', 'line' => 14),
-            'message' => 'log',
-        );
-
-        $message = $formatter->format($record);
-
-        $this->assertEquals(
-            array(
-                'meh',
-                array(
-                    'message' => 'log',
-                    'context' => array('from' => 'logger'),
-                    'extra' => array('ip' => '127.0.0.1'),
-                ),
-                'test : 14',
-                'error'
-            ),
-            $message
-        );
-    }
-
-    /**
-     * @covers Monolog\Formatter\ChromePHPFormatter::format
-     */
-    public function testFormatWithoutContext()
-    {
-        $formatter = new ChromePHPFormatter();
-        $record = array(
-            'level' => Logger::DEBUG,
-            'level_name' => 'DEBUG',
-            'channel' => 'meh',
-            'context' => array(),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array(),
-            'message' => 'log',
-        );
-
-        $message = $formatter->format($record);
-
-        $this->assertEquals(
-            array(
-                'meh',
-                'log',
-                'unknown',
-                'log'
-            ),
-            $message
-        );
-    }
-
-    /**
-     * @covers Monolog\Formatter\ChromePHPFormatter::formatBatch
-     */
-    public function testBatchFormatThrowException()
-    {
-        $formatter = new ChromePHPFormatter();
-        $records = array(
-            array(
-                'level' => Logger::INFO,
-                'level_name' => 'INFO',
-                'channel' => 'meh',
-                'context' => array(),
-                'datetime' => new \DateTime("@0"),
-                'extra' => array(),
-                'message' => 'log',
-            ),
-            array(
-                'level' => Logger::WARNING,
-                'level_name' => 'WARNING',
-                'channel' => 'foo',
-                'context' => array(),
-                'datetime' => new \DateTime("@0"),
-                'extra' => array(),
-                'message' => 'log2',
-            ),
-        );
-
-        $this->assertEquals(
-            array(
-                array(
-                    'meh',
-                    'log',
-                    'unknown',
-                    'info'
-                ),
-                array(
-                    'foo',
-                    'log2',
-                    'unknown',
-                    'warn'
-                ),
-            ),
-            $formatter->formatBatch($records)
-        );
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/tests/Monolog/Formatter/ElasticaFormatterTest.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/tests/Monolog/Formatter/ElasticaFormatterTest.php b/vendor/monolog/monolog/tests/Monolog/Formatter/ElasticaFormatterTest.php
deleted file mode 100644
index 546e5c2..0000000
--- a/vendor/monolog/monolog/tests/Monolog/Formatter/ElasticaFormatterTest.php
+++ /dev/null
@@ -1,79 +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\Formatter;
-
-use Monolog\Logger;
-
-class ElasticaFormatterTest extends \PHPUnit_Framework_TestCase
-{
-    public function setUp()
-    {
-        if (!class_exists("Elastica\Document")) {
-            $this->markTestSkipped("ruflin/elastica not installed");
-        }
-    }
-
-    /**
-     * @covers Monolog\Formatter\ElasticaFormatter::__construct
-     * @covers Monolog\Formatter\ElasticaFormatter::format
-     * @covers Monolog\Formatter\ElasticaFormatter::getDocument
-     */
-    public function testFormat()
-    {
-        // test log message
-        $msg = array(
-            'level' => Logger::ERROR,
-            'level_name' => 'ERROR',
-            'channel' => 'meh',
-            'context' => array('foo' => 7, 'bar', 'class' => new \stdClass),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array(),
-            'message' => 'log',
-        );
-
-        // expected values
-        $expected = $msg;
-        $expected['datetime'] = '1970-01-01T00:00:00+0000';
-        $expected['context'] = array(
-            'class' => '[object] (stdClass: {})',
-            'foo' => 7,
-            0 => 'bar',
-        );
-
-        // format log message
-        $formatter = new ElasticaFormatter('my_index', 'doc_type');
-        $doc = $formatter->format($msg);
-        $this->assertInstanceOf('Elastica\Document', $doc);
-
-        // Document parameters
-        $params = $doc->getParams();
-        $this->assertEquals('my_index', $params['_index']);
-        $this->assertEquals('doc_type', $params['_type']);
-
-        // Document data values
-        $data = $doc->getData();
-        foreach (array_keys($expected) as $key) {
-            $this->assertEquals($expected[$key], $data[$key]);
-        }
-    }
-
-    /**
-     * @covers Monolog\Formatter\ElasticaFormatter::getIndex
-     * @covers Monolog\Formatter\ElasticaFormatter::getType
-     */
-    public function testGetters()
-    {
-        $formatter = new ElasticaFormatter('my_index', 'doc_type');
-        $this->assertEquals('my_index', $formatter->getIndex());
-        $this->assertEquals('doc_type', $formatter->getType());
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/tests/Monolog/Formatter/FlowdockFormatterTest.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/tests/Monolog/Formatter/FlowdockFormatterTest.php b/vendor/monolog/monolog/tests/Monolog/Formatter/FlowdockFormatterTest.php
deleted file mode 100644
index 1b2fd97..0000000
--- a/vendor/monolog/monolog/tests/Monolog/Formatter/FlowdockFormatterTest.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\Formatter;
-
-use Monolog\Logger;
-use Monolog\TestCase;
-
-class FlowdockFormatterTest extends TestCase
-{
-    /**
-     * @covers Monolog\Formatter\FlowdockFormatter::format
-     */
-    public function testFormat()
-    {
-        $formatter = new FlowdockFormatter('test_source', 'source@test.com');
-        $record = $this->getRecord();
-
-        $expected = array(
-            'source' => 'test_source',
-            'from_address' => 'source@test.com',
-            'subject' => 'in test_source: WARNING - test',
-            'content' => 'test',
-            'tags' => array('#logs', '#warning', '#test'),
-            'project' => 'test_source',
-        );
-        $formatted = $formatter->format($record);
-
-        $this->assertEquals($expected, $formatted['flowdock']);
-    }
-
-    /**
-     * @ covers Monolog\Formatter\FlowdockFormatter::formatBatch
-     */
-    public function testFormatBatch()
-    {
-        $formatter = new FlowdockFormatter('test_source', 'source@test.com');
-        $records = array(
-            $this->getRecord(Logger::WARNING),
-            $this->getRecord(Logger::DEBUG),
-        );
-        $formatted = $formatter->formatBatch($records);
-
-        $this->assertArrayHasKey('flowdock', $formatted[0]);
-        $this->assertArrayHasKey('flowdock', $formatted[1]);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/tests/Monolog/Formatter/GelfMessageFormatterTest.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/tests/Monolog/Formatter/GelfMessageFormatterTest.php b/vendor/monolog/monolog/tests/Monolog/Formatter/GelfMessageFormatterTest.php
deleted file mode 100644
index 6ac1485..0000000
--- a/vendor/monolog/monolog/tests/Monolog/Formatter/GelfMessageFormatterTest.php
+++ /dev/null
@@ -1,204 +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\Formatter;
-
-use Monolog\Logger;
-
-class GelfMessageFormatterTest extends \PHPUnit_Framework_TestCase
-{
-    public function setUp()
-    {
-        if (!class_exists('\Gelf\Message')) {
-            $this->markTestSkipped("graylog2/gelf-php or mlehner/gelf-php is not installed");
-        }
-    }
-
-    /**
-     * @covers Monolog\Formatter\GelfMessageFormatter::format
-     */
-    public function testDefaultFormatter()
-    {
-        $formatter = new GelfMessageFormatter();
-        $record = array(
-            'level' => Logger::ERROR,
-            'level_name' => 'ERROR',
-            'channel' => 'meh',
-            'context' => array(),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array(),
-            'message' => 'log',
-        );
-
-        $message = $formatter->format($record);
-
-        $this->assertInstanceOf('Gelf\Message', $message);
-        $this->assertEquals(0, $message->getTimestamp());
-        $this->assertEquals('log', $message->getShortMessage());
-        $this->assertEquals('meh', $message->getFacility());
-        $this->assertEquals(null, $message->getLine());
-        $this->assertEquals(null, $message->getFile());
-        $this->assertEquals($this->isLegacy() ? 3 : 'error', $message->getLevel());
-        $this->assertNotEmpty($message->getHost());
-
-        $formatter = new GelfMessageFormatter('mysystem');
-
-        $message = $formatter->format($record);
-
-        $this->assertInstanceOf('Gelf\Message', $message);
-        $this->assertEquals('mysystem', $message->getHost());
-    }
-
-    /**
-     * @covers Monolog\Formatter\GelfMessageFormatter::format
-     */
-    public function testFormatWithFileAndLine()
-    {
-        $formatter = new GelfMessageFormatter();
-        $record = array(
-            'level' => Logger::ERROR,
-            'level_name' => 'ERROR',
-            'channel' => 'meh',
-            'context' => array('from' => 'logger'),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array('file' => 'test', 'line' => 14),
-            'message' => 'log',
-        );
-
-        $message = $formatter->format($record);
-
-        $this->assertInstanceOf('Gelf\Message', $message);
-        $this->assertEquals('test', $message->getFile());
-        $this->assertEquals(14, $message->getLine());
-    }
-
-    /**
-     * @covers Monolog\Formatter\GelfMessageFormatter::format
-     * @expectedException InvalidArgumentException
-     */
-    public function testFormatInvalidFails()
-    {
-        $formatter = new GelfMessageFormatter();
-        $record = array(
-            'level' => Logger::ERROR,
-            'level_name' => 'ERROR',
-        );
-
-        $formatter->format($record);
-    }
-
-    /**
-     * @covers Monolog\Formatter\GelfMessageFormatter::format
-     */
-    public function testFormatWithContext()
-    {
-        $formatter = new GelfMessageFormatter();
-        $record = array(
-            'level' => Logger::ERROR,
-            'level_name' => 'ERROR',
-            'channel' => 'meh',
-            'context' => array('from' => 'logger'),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array('key' => 'pair'),
-            'message' => 'log'
-        );
-
-        $message = $formatter->format($record);
-
-        $this->assertInstanceOf('Gelf\Message', $message);
-
-        $message_array = $message->toArray();
-
-        $this->assertArrayHasKey('_ctxt_from', $message_array);
-        $this->assertEquals('logger', $message_array['_ctxt_from']);
-
-        // Test with extraPrefix
-        $formatter = new GelfMessageFormatter(null, null, 'CTX');
-        $message = $formatter->format($record);
-
-        $this->assertInstanceOf('Gelf\Message', $message);
-
-        $message_array = $message->toArray();
-
-        $this->assertArrayHasKey('_CTXfrom', $message_array);
-        $this->assertEquals('logger', $message_array['_CTXfrom']);
-    }
-
-    /**
-     * @covers Monolog\Formatter\GelfMessageFormatter::format
-     */
-    public function testFormatWithContextContainingException()
-    {
-        $formatter = new GelfMessageFormatter();
-        $record = array(
-            'level' => Logger::ERROR,
-            'level_name' => 'ERROR',
-            'channel' => 'meh',
-            'context' => array('from' => 'logger', 'exception' => array(
-                'class' => '\Exception',
-                'file'  => '/some/file/in/dir.php:56',
-                'trace' => array('/some/file/1.php:23', '/some/file/2.php:3')
-            )),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array(),
-            'message' => 'log'
-        );
-
-        $message = $formatter->format($record);
-
-        $this->assertInstanceOf('Gelf\Message', $message);
-
-        $this->assertEquals("/some/file/in/dir.php", $message->getFile());
-        $this->assertEquals("56", $message->getLine());
-    }
-
-    /**
-     * @covers Monolog\Formatter\GelfMessageFormatter::format
-     */
-    public function testFormatWithExtra()
-    {
-        $formatter = new GelfMessageFormatter();
-        $record = array(
-            'level' => Logger::ERROR,
-            'level_name' => 'ERROR',
-            'channel' => 'meh',
-            'context' => array('from' => 'logger'),
-            'datetime' => new \DateTime("@0"),
-            'extra' => array('key' => 'pair'),
-            'message' => 'log'
-        );
-
-        $message = $formatter->format($record);
-
-        $this->assertInstanceOf('Gelf\Message', $message);
-
-        $message_array = $message->toArray();
-
-        $this->assertArrayHasKey('_key', $message_array);
-        $this->assertEquals('pair', $message_array['_key']);
-
-        // Test with extraPrefix
-        $formatter = new GelfMessageFormatter(null, 'EXT');
-        $message = $formatter->format($record);
-
-        $this->assertInstanceOf('Gelf\Message', $message);
-
-        $message_array = $message->toArray();
-
-        $this->assertArrayHasKey('_EXTkey', $message_array);
-        $this->assertEquals('pair', $message_array['_EXTkey']);
-    }
-
-    private function isLegacy()
-    {
-        return interface_exists('\Gelf\IMessagePublisher');
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/tests/Monolog/Formatter/JsonFormatterTest.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/tests/Monolog/Formatter/JsonFormatterTest.php b/vendor/monolog/monolog/tests/Monolog/Formatter/JsonFormatterTest.php
deleted file mode 100644
index 69e2007..0000000
--- a/vendor/monolog/monolog/tests/Monolog/Formatter/JsonFormatterTest.php
+++ /dev/null
@@ -1,78 +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\Formatter;
-
-use Monolog\Logger;
-use Monolog\TestCase;
-
-class JsonFormatterTest extends TestCase
-{
-    /**
-     * @covers Monolog\Formatter\JsonFormatter::__construct
-     * @covers Monolog\Formatter\JsonFormatter::getBatchMode
-     * @covers Monolog\Formatter\JsonFormatter::isAppendingNewlines
-     */
-    public function testConstruct()
-    {
-        $formatter = new JsonFormatter();
-        $this->assertEquals(JsonFormatter::BATCH_MODE_JSON, $formatter->getBatchMode());
-        $this->assertEquals(true, $formatter->isAppendingNewlines());
-        $formatter = new JsonFormatter(JsonFormatter::BATCH_MODE_NEWLINES, false);
-        $this->assertEquals(JsonFormatter::BATCH_MODE_NEWLINES, $formatter->getBatchMode());
-        $this->assertEquals(false, $formatter->isAppendingNewlines());
-    }
-
-    /**
-     * @covers Monolog\Formatter\JsonFormatter::format
-     */
-    public function testFormat()
-    {
-        $formatter = new JsonFormatter();
-        $record = $this->getRecord();
-        $this->assertEquals(json_encode($record)."\n", $formatter->format($record));
-
-        $formatter = new JsonFormatter(JsonFormatter::BATCH_MODE_JSON, false);
-        $record = $this->getRecord();
-        $this->assertEquals(json_encode($record), $formatter->format($record));
-    }
-
-    /**
-     * @covers Monolog\Formatter\JsonFormatter::formatBatch
-     * @covers Monolog\Formatter\JsonFormatter::formatBatchJson
-     */
-    public function testFormatBatch()
-    {
-        $formatter = new JsonFormatter();
-        $records = array(
-            $this->getRecord(Logger::WARNING),
-            $this->getRecord(Logger::DEBUG),
-        );
-        $this->assertEquals(json_encode($records), $formatter->formatBatch($records));
-    }
-
-    /**
-     * @covers Monolog\Formatter\JsonFormatter::formatBatch
-     * @covers Monolog\Formatter\JsonFormatter::formatBatchNewlines
-     */
-    public function testFormatBatchNewlines()
-    {
-        $formatter = new JsonFormatter(JsonFormatter::BATCH_MODE_NEWLINES);
-        $records = $expected = array(
-            $this->getRecord(Logger::WARNING),
-            $this->getRecord(Logger::DEBUG),
-        );
-        array_walk($expected, function (&$value, $key) {
-            $value = json_encode($value);
-        });
-        $this->assertEquals(implode("\n", $expected), $formatter->formatBatch($records));
-    }
-}