pkgsrc/devel
fhajny 8abe3caa43 Update devel/kafka to 0.11.0.0.
New Feature
- KIP-146: Support per-connector/per-task classloaders in Connect
- Add Record Headers
- Add purgeDataBefore() API in AdminClient
- Add KStream.peek(ForeachAction)
- Add a tool to Reset Consumer Group Offsets
- Add internal leave.group.on.close config to consumer
- Add Exactly-Once Semantics to Streams
- Implement Transactional Coordinator
- Range Scan for Windowed State Stores

Improvement
- Extend wire protocol to allow CRC32C
- Cluster collection returning methods should never return null
- Add Prompt to kafka-console-producer
- Allow users greater access to register custom streams metrics
- Exponential backoff for broker reconnect attempts (KIP-144)
- Add JMH module for Benchmarks
- Split the ProducerBatch and resend when received
  RecordTooLargeException
- Allow per stream/table timestamp extractor
- support throttling on request rate
- Replication Quota Tests: Ensure ZK updated before tests start
- REST configuration not visible in connector properties config files
- TopicCommand --describe shows topics marked for deletion as
  under-replicated and unavailable (KIP-137)
- RocksDB checkpoint files lost on kill -9
- Treat null-key records the same way for joins and aggreations
- Per listener security setting overrides (KIP-103)
- Kafka does not offer kafka-configs.bat on Windows box
- Parametrize streams benchmarks to run at scale
- Error message from Struct.validate() should include the name of the
  offending field.
- Add application.id to StreamThread name
- Improve Streams Reset Tool console output
- Add Float serializer, deserializer, serde
- Exploit #peek to implement #print() and other methods
- The Kafka build should run findbugs
- Inner classes which don't need a reference to the outer class should
  be static
- Fix findbugs warnings in kafka-tools
- throw NoOffsetForPartitionException once for all assigned partitions
  from poll
- Stream round-robin scheduler is inneficient
- Fix several FindBugs warnings in Clients and Connect
- SCRAM secret's should be better protected with Zookeeper ACLs
- set internal.leave.group.on.close to false in KafkaStreams
- Add listener tag to socket-server-metrics.connection-... metrics
- Followups from KIP-101
- We shouldn't pass the underlying exception to
  RetriableCommitFailedException when an async offset commit fails.
- Optionally print out metrics after running the perf tests
- ReassignPartitionsCommand should protect against empty replica list
  assignment
- Censor SCRAM config change logging
- DumpLogSegments should not open index files with `rw`
- Add support for reading PID snapshot files to DumpLogSegments
- Improve internal Task APIs
- Trunk compatibility tests should test against 0.10.2
- Improve message for Kafka failed startup with non-Kafka data in
  data.dirs
- Controlled shutdown timeout message improvement
- reassign-partitions to check if broker of ID exists in cluster
- Add option "dry run" to Streams application reset tool
- AdminClient: add controller and clusterId methods to
  DescribeClusterResults
- KIP-153: Include only client traffic in BytesOutPerSec metric
- Application Reset Tool does not need to seek for internal topics
- New Short serializer, deserializer, serde
- Change Default unclean.leader.election.enabled from True to False
- Sticky Assignor should not cache the calculated assignment (KIP-54
  follow-up)
- Support ExtendedDeserializer in Kafka Streams
- Remove Broker ACL resource type
- Request log should log throttle time
- Generate javadoc for AdminClient and show configs in documentation
- Annoying braces showed on log.error using streams

Bug
- Implement generation/term per leader to reconcile messages correctly
- Hold the produce request with ack > 1 in purgatory until replicas'
  HW has larger than the produce offset (KIP-101)
- Delete consumer offsets from kafka once the topic is deleted
- Clean up Controller Object on forced Resignation
- ConsumerGroupCommand throws GroupCoordinatorNotAvailableException
  when describing a non-existent group before the offset topic is
  created
- SASL unit tests dont work with IBM JDK
- Follower Broker cannot start if offsets are already out of range
- Remove deprecated producer configs.
- Kafka default -Xloggc settings should include GC log rotation flags
- Streams is creating two ProducerRecords for each send via
  RecordCollector
- Broker faills to start after ungraceful shutdown due to
  non-monotonically incrementing offsets in logs
- Log should check the return value of dir.mkdirs()
- KIP-115: __consumer_offsets wrong number of replicas at startup
- Issue with processing order of consumer properties in console
  consumer
- Exit Strategy: using exceptions instead of inline invocation of
  exit/halt
- Documentation still refers to AsyncProducer and SyncProducer
- KIP-151: Connect REST API should expose whether each connector is a
  source or sink
- KTable doesn't work with ProcessorTopologyTestDriver in Kafka
  0.10.1.0
- rat license check not running in Jenkins
- When using ProcessorTopologyTestDriver, the combination of map and
  .groupByKey does not produce any result
- Set more conservative default values on RocksDB for memory usage
- Significant startup delays in KStreams app
- Kafka should not require SSL trust store password
- When the destination brokers are down or misconfigured in config,
  Streams should fail fast
- Connect Producer and Consumer ignore ssl parameters configured for
  worker
- Annotate integration tests and provide gradle build targets to run
  subsets of tests
- Controller send thread can't stop when broker change listener event
  trigger for dead brokers
- the argument of shell in doc wrong and command parsed error
- Kafka Streams allows you to provide strings with illegal characters
  for internal topic names
- gradle-generated core eclipse project has incorrect source folder
  structure
- Refresh consumer metadata more frequently for unknown subscribed
  topics
- KIP-154: Connect should create internal topics
- Fix Streams window retention policy
- KIP-100 api changes break Java 8 lambda expressions in some cases
- Python VerifiableConsumer service has thread-safety bug for
  event_handlers
- Avoid unnecessary task movement across threads during rebalance
- OffsetValidationTest fails validation with "Current position greater
  than the total number of consumed records"
- StreamsKafkaClient drops security configs
- Fix Transient failure in
  BrokerApiVersionsCommandTest.checkBrokerApiVersionCommandOutput
- Implement remaining KIP-66 SMTs
- Fix logic for re-checking if internal topic is ready
- connect jars are missing LICENSE/NOTICE files
- Timed out waiting for consumption in
  OffsetValidationTest.test_broker_failure
- Clean up of state directories can possibly remove stores that are
  about to be used by another thread
- KafkaConsumer#commitSync should clone its input
- Fix deadlock issue during MM shutdown
- Remove generic type of class ClientState
- Memory leak in RecordAccumulator.append
- Streams_bounce test failing occassionally
- fix join-time-max and sync-time-max MeasurableStat type
- Streams Simple Benchmark MB/sec calculation is not correct for Join
  operations
- SimpleBenchmark test fails for streams
- Improve NetworkClient trace logging of request details
- Connect WorkerSinkTask is missing checks for NO_TIMESTAMP
- org.apache.kafka.clients.producer.KafkaProducerTest#testConstructorFailureCloseResource
  and Similar Tests are Failing on some Systems (127.0.53.53 Collision
  Warning)
- Implement graceful handling for improperly formed compressed message
  sets
- Kafka client Heartbeat thread use all the cpu.
- Failure in
  kafka/tests/kafkatest/tests/core/security_rolling_upgrade_test.py
- KIP-128: Blackbox or pass through converter or ByteArrayConverter
  for connect
- Broker level configuration 'log.segment.bytes' not used when
  'segment.bytes' not configured per topic.
- ProcessorTopologyTestDriver does not forward extracted timestamps to
  internal topics
- Kafka cannot recover after a disk full
- Kafka Streams - unable to add state stores when using wildcard
  topics on the source
- Fix some findbugs warnings in Kafka Java client
- Streams State transition ASCII diagrams need fixing and polishing
- KafkaConsumer: ConsumerConfig gets logged twice.
- docker/run_tests.sh should set up /opt/kafka-dev to be the source
  directory
- SchemaBuilder should be more lax about checking that fields are
  unset if they are being set to the same value
- ReplicaFetchThread may fail to create due to existing metric
- ZookeeperLeaderElector not respecting zookeeper.set.acl
- Fix some findbugs warnings in Kafka Streams
- ProcessorTopologyTestDriver does not work when using .through()
- Config validation in Connector plugins need to compare against both
  canonical and simple class names
- NetworkClient should only consider a connection to be fail after
  attempt to connect
- Stream thread getting into deadlock state while trying to get
  rocksdb lock in retryWithBackoff
- SessionStore.fetch(key) is a performance bottleneck
- Struct SchemaBuilder should not allow duplicate fields.
- Querying window store may return unwanted keys
- Kafka Secure Migrator tool doesn't secure all the nodes
- Kafka console consumer property is ignored
- Kafka Connect does not log connector configuration errors
- processstreamwithcachedstatestore and other streams benchmarks fail
  occasionally
- kafka.request.logger TRACE regression
- Fix findbugs "default character set in use" warnings
- Fix findbugs "format string should use %n rather than \n" in tools
- Fix findbugs warnings in kafka-core
- Make ProduceRequest thread-safe
- Utils#delete should correctly handle I/O errors and symlinks
- Remove unused code for reading Shell command stdout and add unit
  test
- Add streams tests with brokers failing
- Document that stores must not be closed when Processors are closed
- Fix findbugs warnings in Kafka-Connect-API
- Add a configurable delay to the initial consumer group rebalance
- KStreamsTestDriver fails with NPE when KStream.to() sinks are used
- Transformation Key/Value type references should be to class name(),
  not canonicalName()
- Batch resetting offsets in Streams' StoreChangelogReader
- Kafka Connect: Offset committing times out before expected
- Fix an "unread field" findbugs warning in streams examples
- Suppress findbugs warnings about machine-generated code in
  jmh-benchmarks
- remove controller concurrent access to non-threadsafe NetworkClient,
  Selector, and SSLEngine
- Delete the kafka to prefix the name of the keystore and truststore
  file will be more suitable
- kafka-connect: fix findbugs issues in connect/runtime
- testReprocessingFromScratch unit test failure
- Fix findbugs warnings in kafka-clients
- Fix remaining findbugs warnings in Kafka Streams
- StreamThread should catch InvalidTopicException
- JoinIntegrationTest fails occasionally
- Fail the build when findbugs fails
- SSL Channel not ready but tcp is established and the server is hung
  will not sending metadata
- running multiple kafka streams instances causes one or more instance
  to get into file contention
- Increase number of Streams producer retries from the default of 0
- InFlightRequests#isEmpty() always returns false
- Add FindCoordinatorRequest RPC stub and update InitPidRequest for
  KIP-98
- NullPointerException while using GlobalKTable in KafkaStreams
- Chroot check should be done for each ZkUtils instance
- Avoid DNS reverse lookup in security-critical TLS code path
- Kafka Streams skipped-records-rate sensor producing nonzero values
  even when FailOnInvalidTimestamp is used as extractor
- Kafka Streams stuck rebalancing after exception thrown in rebalance
  listener
- Defer exception to the next pollOnce() if consumer's fetch position
  has already increased
- PartitionRecords.fetchRecords(...) should defer exception to the
  next call if iterator has already moved across any valid record
- two versions of jackson-annotations-xxx.jar in distribution tgz
- Update topic expiry time in Metadata every time the topic metadata
  is requested
- some spelling error in code comment
- Kafka Streams SessionStore.findSessions javadoc broken
- ThreadCacheTest.cacheOverheadsSmallValues fails intermittently
- Replica Deletion Regression from KIP-101
- ProducerPerformanceService failing due to parsing error
- Remove KafkaController's incrementControllerEpoch method parameter
- Transient test failure
  SocketServerTest.testMetricCollectionAfterShutdown
- Controller Health Metrics (KIP-143)
- Flaky ResetIntegrationTest
- Windows platform does not offer kafka-broker-api-versions.bat
- MinTimestampTracker uses confusing variable names
- LZ4 decompression is 4-5x slower than Snappy on small batches /
  messages
- SetSchemaMetadata does not replace the schemas in structs correctly
- streams task gets stuck after re-balance due to LockException
- KafkaConsumer.close should be idempotent
- KafkaAdminClientIntegration test should wait until metadata is
  propagated to all brokers
- CachingSessionStore doesn't fetchPrevious correctly.
- SASL tests failing with Could not find a 'KafkaServer' or
  'sasl_plaintext.KafkaServer' entry in the JAAS configuration
- RocksDb might stall in environments with 1 core only
- RocksDbStore#openIterators should be synchronized, since it is
  accessed from multiple threads
- Percentilles are calculated incorrectly
- CachingSessionStore doesn't use the default keySerde.
- RocksDBSessionStore doesn't use default aggSerde.
- KafkaConsumer should not skip a corrupted record after throwing an
  exception.
- IllegalStateException in ensureOpenForRecordAppend
- Small JavaDoc fix for AdminClient#describeTopics
- Cached Session/Window store may return error on
  iterator.peekNextKey()
- NullPointerException (NPE) in
  SourceNodeRecordDeserializer.deserialize
- Reflections logs excessive warnings when scanning classpaths
- Recommended values for Connect transformations contain the wrong
  class name
- Kafka broker fails to start if a topic containing dot in its name is
  marked for delete but hasn't been deleted during previous uptime
- Regression in on-disk log size when using Snappy compression with
  0.8.2 log message format
- GlobalKTable does not checkpoint offsets after restoring state
- Tests which delete singleton metrics break subsequent metrics tests
- handleFetchRequest should do down conversion after throttling
- kakfa-clients consume 100% CPU with manual partition assignment when
  network connection is lost
- Move ACLs, Config, NodeVersions classes into org.apache.kafka.common
- Follow-up improvements for consumer offset reset tool (KIP-122)
- kafka-console-consumer: `--value-deserializer` is not working but
  `--property value.deserializer` does
- One StopReplicaRequest will caused two Responses
- Do not apply exponential backoff if users have overridden
  reconnect.backoff.ms
- PlainSaslServerFactory should allow a null Map in getMechanismNames
- FetchRequest doesn't implement toString
- Missing logging information in ReplicaFetcher
- Stores not queryable after one thread died
- Log cleaning can increase message size and cause cleaner to crash
  with buffer overflow
- MemoryRecords.filterTo can return corrupt data if output buffer is
  not large enough
- AdminClient: add close with timeout, fix some timeout bugs
- Connection Lose during Kafka Kerberos Renewal process
- Replica list in the metadata cache on the broker may have different
  order from zookeeper
- rocksdb.config.setter must be a class instance, not a class name
- ListGroup requires Describe on Cluster, but the command-line
  AclCommand tool does not allow this to be set
- There is a Misspell in ResetIntegrationTest
- Change message.timestamp.difference.max.ms back to Long.MaxValue
- Some socket connections not closed after restart of Kafka Streams
- KafkaConsumer occasionally hits IllegalStateException
- Modify Unstable annotations in Streams API
- baseTimestamp should always have a create timestamp
- MirrorMaker not preserving headers
- Down-converted uncompressed batches should respect fetch offset
- Add EOS integration tests for Streams API
- Add EOS system tests for Streams API
- Kafka Streams skipped-records-rate sensor produces nonzero values
  when the timestamps are valid
- ConsoleConsumer prints out object addresses rather than what is
  expected
- AdminClient gets "server returned information about unknown
  correlation ID" when communicating with older brokers
- Transactions: Concurrent transactional consumer loses messages when
  there are broker bounces
- Transient test failure:
  KafkaConsumerTest.testChangingRegexSubscription
- Log recovery can fail if topic names contain one of the index
  suffixes
- Transactional Producer allows batches to expire and commits
  transactions regardless
- KafkaAdminClient#timeoutCallsInFlight does not work as expected
- Distributed Herder Deadlocks on Shutdown
- Add more AdminClient checks to ClientCompatibilityTest
- Log cleaner fails due to large offset in segment file
- Console consumer offset commit regression
- TransactionCoordinator doesn't complete transition to PrepareCommit
  state
- TransactionCoordinator doesn't complete transition to CompleteCommit
- ZkUtils.getAllPartitions() may fail if a topic is marked for
  deletion
- Multiple produce request failures causes invalid state transition in
  TransactionManager
- Transient test failure:
  SaslPlainSslEndToEndAuthorizationTest.testNoProduceWithDescribeAcl
- Streams producer `client.id` are not unique for EOS
- TimestampConverter's "type" config conflicts with the basic
  Transformation "type" config
- Flaky test
  TransactionsTest.testReadCommittedConsumerShouldNotSeeUndecidedData
- Scripts to startup Connect in system tests have too short a timeout
- Update java docs for consumer and producer to be up to date for EOS
- Producer fails with NPE if compressed V0 or V1 record is larger than
  batch size
- MemoryRecordsBuilder.hasRoomfor doesn't take into account the
  headers while computing available space
- Controller incorrectly logs rack information when new brokers are
  added
- Connector validate REST endpoint returning duplicate entries in
  "groups"
- Connector config validation REST API endpoint not including fields
  for transformations
- TransactionalProducer sleeps unnecessarily long during back to back
  transactions
- org.apache.kafka logging should go to server.log
- The ProducerPerformance tool should support transactions
- Connect validation API stops returning recommendations for some
  fields after the right sequence of requests

Task
- Remove deprecated APIs for 0.11.0.0
- Drop support for Scala 2.10 (KIP-119)
- Remove unstable markers from Connect APIs
- KTable materialization and improved semantics

Test
- Transient failure in
  ZooKeeperSecurityUpgradeTest.test_zk_security_upgrade with
  security_protocol = SASL_PLAINTEXT, SSL
- Test with two SASL_SSL listeners with different JAAS contexts
- Implement KIP-98 transactional methods in the MockProducer
- Add cases for concurrent transactional reads and writes in system
  tests
- SyncProducerTest.testReachableServer has become flaky

Sub-task
- KIP-54: Add rebalance with a minimal number of reassignments to
  server-defined strategy list
- ProducerSendTest.testCloseWithZeroTimeoutFromCallerThread Transient
  Failure
- Transient Failure in kafka.api.PlaintextProducerSendTest.testFlush
- Mark the old Scala consumer and related classes as deprecated
- Create Java Admin Client
- Implement KIP-140 RPCs and APIs for creating, altering, and listing
  ACLs
- Describe/Alter Configs protocol, server and client (KIP-133)
- Transient test failure:
  kafka.api.SslProducerSendTest.testSendNonCompressedMessageWithCreateTime
- Unstable test
  KStreamRepartitionJoinTest.shouldCorrectlyRepartitionOnJoinOperations
- Transient test failure:
  ConsumerBounceTest.testConsumptionWithBrokerFailures
- Transient failure in QueryableStateIntegrationTest.queryOnRebalance
- Address 2.12 eta-expansion warnings
- Update release process so that Scala 2.12 artifacts are published
- Run tests on travis-ci using docker
- Transient failure in
  org.apache.kafka.clients.consumer.KafkaConsumerTest.testWakeupWithFetchDataAvailable
- QueryableStateIntegrationTest.shouldNotMakeStoreAvailableUntilAllStoresAvailable
  is occasionally failing on jenkins
- Improve test coverage of ProcessorStateManager
- Improve test coverage of StreamsPartitionAssignor
- Improve test coverage of ProcessorTopology
- Improve test coverage AbstractProcessorContext
- Improve test coverage of GlobalStreamThread
- Improve test coverage StreamTask
- Improve test coverage GlobalStateManagerImpl
- Improve test coverage KStreamBuilder
- Improve test coverage MemoryLRUCache
- Improve test coverage of CompositeReadOnlyWindowStore
- Improve test coverage KafkaStreams
- Improve test coverage TopologyBuilder
- Transient test failure:
  ConsumerCoordinatorTest.testHeartbeatThreadClose
- Message format changes for idempotent/transactional producer
- Implement idempotent producer
- Implement transactional clients
- Transient test failure:
  org.apache.kafka.streams.integration.JoinIntegrationTest.shouldCountClicksPerRegion
  (again)
- Consider disabling record level CRC checks for message format V2
- Failure in
  kafka.admin.DescribeConsumerGroupTest.testDescribeExistingGroupWithNoMembersWithNewConsumer
- Implementation and unit tests for request handler thread utilization
  quota
- Add network handler thread utilization to request quota calculation
- Add documentation for request quotas
- Transient failure of AdminClientTest.testDeleteRecordsWithException
- Add producer per task support
- Add request/response classes for transactions (KIP-98)
- KeyValueStore.put may throw exception unrelated to the current put
  attempt
- Exactly-once upgrade notes
- Update Message Delivery Semantics section to take into account
  KIP-98
- convert kafka controller to a single-threaded event queue model
- Additional validation in validateMessagesAndAssignOffsets
- Reconsider default retries for idempotent producer
- add controller integration tests
- Load only batch header when rebuilding producer ID map
- Refactor AdminUtils to use zkUtils methods instad of
  zkUtils.zkClient
- remove preferred replica election state from ControllerContext
- Implement transaction index for KIP-98
- shouldInnerLeftJoin unit test fails
- TransactionCoordinator - Check inter broker protocol and message
  format and raise errors if incompatible
- TransactionCoordinator - Add ACL check for each request
- Change InterBrokerSendThread to use a Queue per broker
- WriteTxnMarkers and complete commit/abort on partition immigration
- Abort long running transactions
- Move coordinatorEpoch from WriteTxnMarkerRequest to TxnMarkerEntry
- KafkaProducer's TransactionManager needs a review on synchronization
- Refactor TransactionCoordinator in-memory structure and error
  handling logic
- KIP-98 : broker side handling for the TxnOffsetCommitRequest
- Add a reference to AdminClient to docs/api.html
- TC should not accept empty string transactional id
- Transient failure:
  ControllerIntegrationTest.testPreferredReplicaLeaderElection
- Log connection termination during authentication
- Transient failure:
  ControllerIntegrationTest.testControllerMoveIncrementsControllerEpoch
- Transient failure: RequestQuotaTest.testResponseThrottleTime
- Avoid expensive initialization of producer state when upgrading
- Add Integration tests for transactional producer
- Autogenerate Consumer Fetcher metrics
- LogCleaner should be transaction-aware
- Handle topic deletion for ongoing transactions
- SaslScramSslEndToEndAuthorizationTest.testNoConsumeWithoutDescribeAclViaSubscribe
- TransactinoCoordinator does not bump epoch when aborting open
  transactions
- Consumer GroupCoordinator should continue to materialize committed
  offsets in offset order even for transactional offset commits
- Remove retention time from TxnOffsetCommit RPC
- Transaction index recovery does not snapshot properly
- Producer should drop queued sends when transaction is aborted
- Fix flaky test LogCleanerTest.testCommitMarkerRemoval
- move all partition and replica state transition rules into their
  states
- TransactionalId authorization should imply ProducerId authorization
- Producer should not send AbortTxn unless transaction has actually
  begun
- TransactionsBounceTest occasionally sees INVALID_TXN_STATE errors
- TransactionBounceTest occasionally fails due to partition errors
- KafkaConsumer.committed() should get latest committed offsets from
  the server
- Review and improve AdminClient Javadoc for the first release
  (KIP-117)
- Review and potentially tweak AdminClient API for the initial release
  (KIP-117)
- TransactionCoordinator must expire transactionalIds
- Protect concurrent access to the cached transaction status
- System tests for KIP-98 / transactions
- Transactions integration test: Use factory methods to keep track of
  open producers and consumers and close them all on tearDown
- Update clients and server code to make sure that epoch and sequence
  numbers wrap around
- AdminClient should not trigger auto creation of topics
- Fix authorization checks in AdminClient
- TC should handle UNSUPPORTED_FOR_MESSAGE_FORMAT in WriteTxnMarker
  response
- reset ControllerContext during resignation
- Update KIP-98 to reflect changes during implementation.
- Update produce/fetch throttle time metrics for any request throttle
- Resolve AddPartitions response error code inconsistency
- Transactions system test with hard broker bounces fails sporadically
- Add additional test cases for batch splitting to ensure
  idempotent/transactional metadata is preserved
- Broker clean bounce test puts the broker into a
  'CONCURRENT_TRANSACTIONS' state permanently
- Broker returns messages beyond "latest stable offset" to
  transactional consumer in read_committed mode
- StackOverFlow error in transaction coordinator
- Producer attempts to send transactional messages before adding
  partitions to transaction
- Fix regression in compressed message iteration affecting magic v0
  and v1
- Transactions: Concurrent transactional consumer reads aborted
  messages
- Last Stable Offset not returned in Fetch request
- Transactional producer cannot find coordinator when trying to abort
  transaction after error
- Transactional producer aborts batches incorrectly in abortable error
  state
- Producer IllegalStateException: Batch has already been completed
- Produce state lost if no snapshot retained
- TransactionalMessageCopier should be force killed on test shutdown
- UnsupportedOperationException in WriteTxnMarkers handler
- Consumer should use last offset from batch to set next fetch offset
- read current brokers from zookeeper upon processing broker change
2017-07-04 14:14:46 +00:00
..
accerciser Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
accerciser3 Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
acme
acr
acunia-jam
adacurses Add devel/adacurses to pkgsrc 2016-12-12 00:36:19 +00:00
adocman
aegis Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
afl Updated afl to 2.44b. 2017-07-04 08:43:54 +00:00
ald
alex
allegro
anjuta Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
ant-contrib
apache-ant Update apache-ant to 1.10.1 2017-02-08 11:50:02 +00:00
apache-ant15
apache-ivy
apache-maven Avoid stderr spam when not using native Java. 2017-06-20 11:52:08 +00:00
apel
appdata-tools Revbump after icu update 2017-04-22 21:03:07 +00:00
apr Warn about "PR" in changelogs. 2017-06-19 20:52:46 +00:00
apr-util Updated apr-util to 1.6.0. 2017-06-19 20:42:16 +00:00
arcanist Phabricator doesn't support PHP-7.0. 2017-06-27 10:35:46 +00:00
arena
argp
argtable
as31
asio
asm2html
astyle
at-spi Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
at-spi2-atk Update at-spi2-atk to 2.22.0 2016-11-25 12:51:41 +00:00
at-spi2-core Update at-spi2-core to 2.22.0 2016-11-25 12:49:00 +00:00
atf Detect built-in ATF on the system. 2017-06-08 13:30:16 +00:00
atk Update atk to 2.24.0 2017-07-03 18:07:44 +00:00
atkmm Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
autoconf
autoconf-archive
autoconf213
autogen
automake Add upstream bug report URL. 2017-06-23 12:52:56 +00:00
automake14
automoc4
avl
avltree
bam
bats
bcc Fix operator precendence problem. Bump revision. 2016-12-22 21:02:19 +00:00
bfg Added devel/bfg version 1.12.14 2016-12-15 20:25:04 +00:00
bglibs Fix build on NetBSD, Linux, Solaris: when linking bg-installer, remove 2017-01-02 14:13:32 +00:00
bin86 Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
binutils binutils: don't include PLIST.gprof on AIX 2017-05-28 02:28:24 +00:00
bison
blame
blib Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
bmake
bmkdep
boa-constructor Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
boehm-gc devel/boehm-gc: Fix functionality on DragonFly 2016-12-03 03:09:26 +00:00
bokken Extend SHA512 checksums to various files I have on my local distfile 2017-03-23 17:06:45 +00:00
boost-build Changes 1.64.0: 2017-04-29 18:31:42 +00:00
boost-docs Changes 1.63.0: 2017-01-01 15:32:47 +00:00
boost-headers Move workaround for missing include from csound6 to main boost package, 2017-06-27 20:08:59 +00:00
boost-jam Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
boost-libs Bump PKGREVISION from enabling log1p and expm1 under NetBSD 2017-05-29 14:39:28 +00:00
bouml
bpython add support for PKGMANDIR 2017-06-27 23:33:08 +00:00
buddy
bugs-everywhere Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
bugzilla Added Missing file with previous commit, INSTALL, sorry 2017-03-19 12:52:57 +00:00
bugzilla3 Updated devel/bugzilla3 to 3.6.8 2017-01-16 14:06:43 +00:00
bullet
byacc
bzr Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
bzr-explorer Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
bzr-gtk Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
bzr-svn Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
bzrtools Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
c-cpp-reference
calltree-perl
capstone
catch Updated devel/catch to 1.5.9 2017-01-04 13:48:02 +00:00
cbrowser
ccache ccache 3.3.4: 2017-02-26 10:17:00 +00:00
cdecl Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
cdk
cervisia Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
cfitsio
cflow
cflow-mode
cgdb
cgen
check
chmlib
chrpath Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
clib Reset MAINTAINER after tonnerre resigned. 2017-04-19 11:24:36 +00:00
clisp-pcre
clisp-syscalls
clisp-wildcard
clisp-zlib
cloc Add cloc 1.72 2017-04-23 03:29:00 +00:00
cmake Changes in 3.8.2 since 3.8.1: 2017-06-01 20:47:25 +00:00
cmake-fedora
cmake-mode
cmocka
cmockery2
cmph Update devel/cmph to version 2.0. 2016-11-20 12:22:48 +00:00
cobol-mode
coccinelle Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
coconut Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
codeville Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
cogito
colordiff Updated colordiff to 1.0.18. 2017-06-19 20:47:15 +00:00
commit-patch
compiz-bcop
compizconfig-backend-gconf Revbump after icu update 2017-04-22 21:03:07 +00:00
concurrencykit
confuse
cook
cppcheck Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
cppunit Fix misc/libreoffice build on netbsd-7/gcc-4.8 2017-05-01 04:16:12 +00:00
cpputest
cproto
cpuflags
cqual
cre2 Updated devel/cr2 from 0.1b6 to 0.3.4 2017-05-07 03:13:24 +00:00
creduce Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
cscope
cssc Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
ctemplate
cunit
cut no route to host. default to cdn. 2017-01-08 13:48:31 +00:00
cutter Revbump after icu update 2017-04-22 21:03:07 +00:00
cvs-fast-export Not MAKE_JOBS_SAFE. 2017-02-14 21:32:04 +00:00
cvs2cl
cvs2html
cvs2svn Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
cvsclone
cvsd
cvsdiff2patch
cvsgraph Recursive revbump from graphics/libwebp 2017-02-28 15:19:58 +00:00
cvslock
cvsps
cvsps3
cvsup-bin
cvsup-gui-bin
cvsutils
cvsync
cxref Ensure the local yywrap is used. Fixes build with newer flex. 2017-01-04 12:46:06 +00:00
darcs Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
darts
dconf Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
dconf-editor Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
ddd
deforaos-asm
deforaos-coder Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
deforaos-configure
deforaos-cpp
deforaos-libsystem Update DeforaOS libSystem to version 0.3.1 2017-04-13 00:41:02 +00:00
dejagnu
delta
dev86
devhelp Revbump after icu update 2017-04-22 21:03:07 +00:00
device-driver-doc-de
devIL Deal with Jasper fallout. 2016-12-17 14:15:27 +00:00
dia2code
diffuse Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
diffutils Updated devel/diffutils to 3.5 2017-01-04 14:04:30 +00:00
distcc
distcc-pump Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
distccmon-gnome Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
distccmon-gtk Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
dlcompat
dmake
dmalloc
doc++
dolphin-plugins Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
dotconf
doxygen Fix null pointer deref in xml generator. Bump revision. 2017-05-19 14:56:00 +00:00
doxymacs
dumpet
easygit
eclipse
ecore Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
edcommon Revbump after icu update 2017-04-22 21:03:07 +00:00
editline
editorconfig-core Uses the wrong commit command when adding this package 2017-05-28 19:59:04 +00:00
eet
eina
eio Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
electric-fence
elf Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
elfcat
elfsh
elftoolchain 1. add lex as a tool, problem shown up by ubuntu LTS bulk build 2017-05-31 22:14:43 +00:00
elib
emacs-ilisp
emacs20-elib
epydoc Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
eric4 Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
erlang-cache_tab Update devel/erlang-cache_tab to 1.0.7. 2017-03-30 10:21:32 +00:00
erlang-ezlib Update devel/erlang-ezlib to 1.0.2. 2017-01-21 20:10:55 +00:00
error
ethos Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
ETL
etrace
exctags
exempi Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
ExmanIDE Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
extra-cmake-modules
fann
fastdep
ffcall Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
fhist
flatzebra
flex Remove now unneeded patch, lilypond seems to build fine without it. 2017-01-12 16:53:22 +00:00
flexdock
flim Use GREP/EGREP and fix regexp. 2017-04-18 16:26:45 +00:00
florist Upgrade USE_LANGUAGES=ada to use lang/gcc5-aux instead of lang/gcc-aux 2016-11-25 20:36:49 +00:00
fortran-utils Extend SHA512 checksums to various files I have on my local distfile 2017-03-23 17:06:45 +00:00
fossil Update MASTER_SITE. 2017-04-22 14:30:58 +00:00
frama-c Revbump after icu update 2017-04-22 21:03:07 +00:00
frink
fromcvs
ftnchek
g-wrap
gccmakedep
GConf Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
GConf-ui Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
gconfmm Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
gcvs
gdb Correct gdb build failure on NetBSD 8.99.1 2017-06-23 19:49:20 +00:00
gdb5
gdb6
gdb7 Add gdb7. it's currently identical to devel/gdb, but not for long. 2017-06-05 10:41:28 +00:00
gdbus-codegen
gdl Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
geany Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
gearmand Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
generate
gengetopt
gentle Ensure the local yywrap is used. Fixes the build of devel/rsltc with 2017-01-04 12:53:49 +00:00
gettext Revert, handled differently. 2017-06-26 21:42:18 +00:00
gettext-asprintf
gettext-lib
gettext-m4
gettext-tools Install "its" files. Needed by msgfmt. 2017-05-15 14:14:04 +00:00
gflags Changes 2.2.0: 2017-03-17 14:49:58 +00:00
gflib
giblib
gindent
git Updated devel/git-{base,contrib,docs,git-gitk} to 2.13.2 2017-06-25 03:15:11 +00:00
git-base Updated devel/git-{base,contrib,docs,git-gitk} to 2.13.2 2017-06-25 03:15:11 +00:00
git-contrib
git-cvs
git-docs Git 2.12 Release Notes 2017-02-25 08:32:57 +00:00
git-gitk Git 2.12 Release Notes 2017-02-25 08:32:57 +00:00
git-remote-hg This package does not use curses. 2017-01-04 17:31:22 +00:00
git-svn
gitolite Updated gitolite to 3.6.6. 2017-06-12 08:24:37 +00:00
glade Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
glade3 Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
glib
glib2 PLIST fix for Darwin 2017-07-03 18:47:29 +00:00
glibmm Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
global Updated global to 6.5.7. 2017-05-29 11:20:53 +00:00
gmake Do not raise stack limits during the build. It messes up ressource 2016-12-17 14:14:06 +00:00
gmp Fix distinfo. 2017-06-15 04:12:32 +00:00
gmtk Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
gnatpython Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
gnome-common
gnustep-base Revbump after icu update 2017-04-22 21:03:07 +00:00
gnustep-examples Revbump after icu update 2017-04-22 21:03:07 +00:00
gnustep-make
gnustep-objc since ../../devel/gnustep-make/buildlink3.mk sets PKGSRC_COMPILER 2016-11-27 09:49:41 +00:00
gnustep-objc-lf2
go-check Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-flags-svent Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-glog Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-gls Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-ini Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-mow-cli Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-nbreader Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-protobuf Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-ratelimit Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-review Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-sys Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
go-termbox Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-testify Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
go-tools Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
gob2
gobject-introspection Update gobject-introspection to 1.50 2016-11-25 13:00:13 +00:00
golint Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
google-api-go-client Revbump all Go packages after the Go 1.8.1 update. 2017-04-13 15:12:03 +00:00
google-glog Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
googletest Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
Gorm Revbump after icu update 2017-04-22 21:03:07 +00:00
gperf Updated gperf to 3.1. 2017-01-12 01:25:03 +00:00
gperftools Changes 2.5: 2017-05-18 18:12:30 +00:00
gprbuild-aux devel/gprbuild-aux: change buildlink default full=>build 2016-11-26 18:34:47 +00:00
gps Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
gputils
gradle Update devel/gradle to 3.4. Fix the package to actually work. 2017-02-28 08:16:09 +00:00
grantlee
grantlee-qt5 Revbump after icu update 2017-04-22 21:03:07 +00:00
gsoap
gst-plugins0.10-pango Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
gst-plugins1-pango Reset PKGREVISION after update. 2017-03-16 14:37:33 +00:00
gtexinfo Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
gtl
guile-gnome Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
guile-lib
guile-slib
guile-www
gyp Updated py-gyp to 0.1pre20161117.940a15ee3f1c89f193cb4c19373b3f6e9ad15b95. 2017-01-11 14:47:51 +00:00
happy
haskell-mode
hdevtools
hdf Ensure the local yywrap is used. Fixes build with newer flex. 2017-01-04 11:17:56 +00:00
hdf5 Update devel/hdf5 and devel/hdf5-c++ to version 1.8.18. 2016-12-03 18:56:36 +00:00
hdf5-c++
heirloom-getopt
heirloom-libcommon
heirloom-what
hoe Update hoe to 3.16.0. 2017-03-12 14:30:30 +00:00
hptools
hs-ansi-terminal
hs-base-unicode-symbols
hs-blaze-builder
hs-cmdargs
hs-cpphs
hs-data-default
hs-data-default-class
hs-data-default-instances-base
hs-data-default-instances-containers
hs-data-default-instances-dlist
hs-data-default-instances-old-locale
hs-deepseq-generics
hs-dlist
hs-exceptions
hs-extensible-exceptions
hs-ghc-mtl
hs-ghc-paths
hs-hashable
hs-haskell-src-exts
hs-hint
hs-lifted-base
hs-mmorph
hs-monad-control
hs-MonadRandom
hs-mtl
hs-primitive
hs-QuickCheck
hs-random
hs-reflection
hs-resourcet
hs-safe
hs-setlocale
hs-split
hs-stm
hs-syb
hs-tagged
hs-text
hs-tf-random
hs-transformers
hs-transformers-base
hs-transformers-compat
hs-uniplate
hs-unordered-containers
hs-utf8-string
hs-vault
hs-vector
hs-vector-algorithms
hs-void
ht
hugs-HUnit
hugs-unix
idiff
idutils
imake
include-what-you-use Fixed building with LLVM 4.0.0 2017-03-17 22:39:30 +00:00
iniparser
intel2gas
intellij-idea-ce
isect
its4
ivykis Update devel/ivykis to 0.42. 2017-05-03 10:43:02 +00:00
jam Extend SHA512 checksums to various files I have on my local distfile 2017-03-23 17:06:45 +00:00
java-subversion Revbump after icu update 2017-04-22 21:03:07 +00:00
javacc
javadeps
jd-gui
jemalloc Set os_overcommits to true on NetBSD since NetBSD does overcommit. 2017-05-17 16:36:46 +00:00
jenkins Update to 2.46.2 2017-05-20 23:52:19 +00:00
jenkins-lts Update to 2.46.2 2017-05-20 23:54:19 +00:00
jflex
jq
js2-mode js2-mode works perfectly fine on emacs25 2017-04-14 00:31:41 +00:00
js_of_ocaml Updated package to latest version, 2.8.3. Changes include: 2016-12-30 12:04:25 +00:00
kafka Update devel/kafka to 0.11.0.0. 2017-07-04 14:14:46 +00:00
kapptemplate Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kbookmarks Revbump after icu update 2017-04-22 21:03:07 +00:00
kbuild
kcachegrind Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kcmutils Revbump after icu update 2017-04-22 21:03:07 +00:00
kconfig Revbump after icu update 2017-04-22 21:03:07 +00:00
kcoreaddons Revbump after icu update 2017-04-22 21:03:07 +00:00
kcrash Revbump after icu update 2017-04-22 21:03:07 +00:00
kdbg
kde-dev-scripts Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kde-dev-utils Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kdeclarative Revbump after icu update 2017-04-22 21:03:07 +00:00
kdesdk-kioslaves Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kdesdk-strigi-analyzers Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kdesdk-thumbnailers Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kdesdk3 Revbump after icu update 2017-04-22 21:03:07 +00:00
kdevelop
kdevelop-base Revbump after icu update 2017-04-22 21:03:07 +00:00
kdevelop4 Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kdevplatform Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kdiff3 Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kdiff3-kde3
kdoctools Revbump after icu update 2017-04-22 21:03:07 +00:00
ki18n Revbump after icu update 2017-04-22 21:03:07 +00:00
kidletime Revbump after icu update 2017-04-22 21:03:07 +00:00
kio Revbump after icu update 2017-04-22 21:03:07 +00:00
kitemmodels Revbump after icu update 2017-04-22 21:03:07 +00:00
knotifications Revbump after icu update 2017-04-22 21:03:07 +00:00
knotifyconfig Revbump after icu update 2017-04-22 21:03:07 +00:00
ko-po-check Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
kompare Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
kpackage Revbump after icu update 2017-04-22 21:03:07 +00:00
kparts Revbump after icu update 2017-04-22 21:03:07 +00:00
kpeople Revbump after icu update 2017-04-22 21:03:07 +00:00
kpty Revbump after icu update 2017-04-22 21:03:07 +00:00
krunner Revbump after icu update 2017-04-22 21:03:07 +00:00
kscope
kservice Revbump after icu update 2017-04-22 21:03:07 +00:00
ktexteditor Revbump after icu update 2017-04-22 21:03:07 +00:00
kyua Fix "make install" in devel/kyua without "tests" package option. 2017-06-07 22:57:02 +00:00
lcc
lcov Update lcov to 1.13 2017-04-10 01:26:26 +00:00
ldapsdk
ldpc
lemon Release 3.19.3: 2017-06-10 19:13:59 +00:00
lettuce Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
libappindicator Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libappindicator3 Extend SHA512 checksums to various files I have on my local distfile 2017-03-23 17:06:45 +00:00
libarena
libargparse
libast
libatomic_ops Updated libatomic_ops to 7.6.0. 2017-05-29 12:55:10 +00:00
libbegemot
libbinio
libblkid
libbonobo
libbonoboui Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libbson Fix nonsense shell syntax. From Robert Elz. 2017-07-03 18:11:27 +00:00
libcerf
libcfg+ Reduce context to avoid 8-bit character. 2016-11-27 09:04:27 +00:00
libcompizconfig Revbump after icu update 2017-04-22 21:03:07 +00:00
libconfig
libctl
libdaemon
libdatrie Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
libdbusmenu-glib Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
libdbusmenu-gtk Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
libdbusmenu-gtk-doc
libdbusmenu-gtk3 Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
libdbusmenu-jsonloader Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
libdbusmenu-qt
libdbusmenu-qt5 Revbump after icu update 2017-04-22 21:03:07 +00:00
libdbusmenu-tools Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
libdevq
libdnsres
libdockapp
libdshconfig
libdwarf Update 20160115 to 20161124 2016-12-11 21:34:26 +00:00
libebml
libelf Add BUILDLINK_INCDIRS per PR 50173. 2017-05-25 06:01:04 +00:00
libestr
libetm
libev
libevent Update patch for current define naming. Fixes SunOS build. 2017-03-08 13:37:55 +00:00
libewf
libexecinfo
libextractor Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libf2c
libffi Implement a W^X-aware closure allocator. Overhead is one page per 2017-05-26 18:55:41 +00:00
libfirm
libFoundation
libFoundation-examples
libfreefare Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
libftdi
libftdi1 Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
libgail-gnome Revbump after icu update 2017-04-22 21:03:07 +00:00
libgcroots
libgee Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
libgee0.6
libgetopt
libgit2 Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
libglade Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libglademm Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
libgnome Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libgnomemm Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
libgnomeui Fix SunOS build with GCC 7.1. 2017-05-25 12:58:34 +00:00
libgnomeuimm Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
libgphoto2
libgsf
libgweather Revbump after icu update 2017-04-22 21:03:07 +00:00
libhfs
libhid Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
libiberty
libidn Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
libindicator Extend SHA512 checksums to various files I have on my local distfile 2017-03-23 17:06:45 +00:00
libindicator-tools Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libindicator3 Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libinotify
libite
libixp
libjit
libjudy
libkgapi Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
libkomparediff2 Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
liblangtag
libltdl
libmaa
libmatchbox
libmcs
libmemcache
libmemcached
libmemmgr
libmimedir
libmm
libmowgli
libmtp Updated libmtp to 1.1.13. 2017-05-16 13:50:06 +00:00
libnet10
libnet11
libnfc Add libnfc-1.7.1 2016-12-16 08:11:55 +00:00
libnjb
libntlm
liboil
liboop
libosip
libowfat Update to 0.31. From the changelog: 2017-06-26 04:52:34 +00:00
libpeas Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libpgm
libphutil Phabricator doesn't support PHP-7.0. 2017-06-27 10:35:46 +00:00
libportlib
libproplist
libpthread_dbg Remove empty distinfo. 2017-03-23 13:38:27 +00:00
librdkafka * Use bash for CONFIG_SHELL 2017-04-24 12:20:37 +00:00
librelp Update devel/librelp to 1.2.14. 2017-07-04 13:19:23 +00:00
librfuncs
librlog
librxspencer
libsafec
libsexy Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libsexymm Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
libsigc++ Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
libsigc++1
libsigsegv Updated libsigsegv to 2.11. 2017-02-27 09:52:47 +00:00
libslang Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
libslang2 Fix bogus flags, now builds on SunOS. 2017-04-20 10:46:09 +00:00
libsmi
libstash
libstatgrab Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
libstree
libstroke
libtai Actually, this code is public-domain. Respect PKG_SYSCONFDIR. 2017-06-26 01:06:07 +00:00
libtar
libtecla
libthai Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
libthrift Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
libtool Unbreak build in environments with fine grained file system times. 2017-03-07 13:21:10 +00:00
libtool-base Update libtool packages to 2.4.6. 2017-03-06 16:14:07 +00:00
libtool-fortran Update libtool packages to 2.4.6. 2017-03-06 16:14:07 +00:00
libtool-info
libts
libusb devel/libusb: ONLY_FOR_PLATFORM=- DragonFly 2016-12-03 04:19:05 +00:00
libusb-compat
libusb1 libusb1: avoid a linux-only dependency on udev. this may harm linux 2017-01-23 18:50:02 +00:00
libuuid
libuv Version 1.12.0 2017-06-24 06:07:44 +00:00
libuxre
libview Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
libvolume_id
libwhisker2
libwnck Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libwnck3 Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
libxenserver Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
libzen Use public SHLIB_TYPE instead of private _OPSYS_SHLIB_TYPE. 2017-06-01 13:30:24 +00:00
libzookeeper
lincvs
linenoise
lldb Correct LLDB build on NetBSD 8.99.1 2017-06-30 00:38:11 +00:00
lmdbg Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
locktests
log4cplus
log4cxx
log4shib
lokalize Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
ltsa
lua-alt-getopt Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
lua-BitOp
lua-coxpcall
lua-filesystem
lua-gi
lua-ljsyscall
lua-lpeg Fix 'make test' target. 2017-01-30 21:16:34 +00:00
lua-lrexlib
lua-lrexlib-onig
lua-lrexlib-pcre
lua-lrexlib-posix
lua-mode
lua-penlight Update devel/lua-penlight to 1.5.2. 2017-04-27 21:52:09 +00:00
lua-posix
lua-rocks
lua-stdlib
lutok Use standard way to test for options. 2016-12-31 09:39:31 +00:00
lwp
m4
m17n-lib Recursive revbump from graphics/libwebp 2017-02-28 15:19:58 +00:00
mad-flute Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
magit
makedepend
makedepf90
maketool
man-pages
mantis Update to 2.4.1 2017-05-21 07:16:49 +00:00
mate-common Update mate-common to 1.18.0 2017-06-23 17:16:21 +00:00
matio
mcpp
mdds Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
mdds1.2 Updated mdds1.2 to 1.2.3. 2017-05-29 10:24:02 +00:00
meld Updated meld to 3.17.2. 2017-06-14 14:03:54 +00:00
mell
memcached Changes 1.4.34: 2017-02-16 11:10:53 +00:00
menhir Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
mercurial
mico Reset MAINTAINER after tonnerre resigned. 2017-04-19 11:24:36 +00:00
mk-configure Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
mkcmd
mm-common
MoarVM Update MoarVM to 2017.06. Bump API_DEPENDS too, as functions have been 2017-06-20 19:06:42 +00:00
mono-addins Revbump after icu update 2017-04-22 21:03:07 +00:00
mono-tools Revbump after icu update 2017-04-22 21:03:07 +00:00
monodevelop Revbump after icu update 2017-04-22 21:03:07 +00:00
monodevelop-database Revbump after icu update 2017-04-22 21:03:07 +00:00
monotone Revbump after icu update 2017-04-22 21:03:07 +00:00
monotone-server
monotone-viz Revbump after icu update 2017-04-22 21:03:07 +00:00
mph
mr Distfile no longer available on GitHub. Fetch from ${MASTER_SITE_LOCAL}. 2017-03-05 12:25:28 +00:00
msgpack
nana
nant Revbump after icu update 2017-04-22 21:03:07 +00:00
nasm Version 2.13.01 2017-05-18 21:44:42 +00:00
nbpatch
ncc
ncurses Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
ncursesw For the sake of cmake and other tools that like to look for physical 2016-12-20 15:06:52 +00:00
netbeans-ide
netbsd-iscsi-lib
netcdf Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
netcdf-cxx Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
netcdf-fortran Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
newfile
ninja-build Include missing header. 2017-02-09 00:24:23 +00:00
noweb
npapi-sdk
npth Updated npth to 1.5. 2017-06-14 15:54:08 +00:00
nqc
nsis
nspr Update to 4.15 2017-07-03 12:18:17 +00:00
nspr-reference
nss Update to 3.31 2017-06-14 11:18:55 +00:00
ObjectiveLib Revbump after icu update 2017-04-22 21:03:07 +00:00
ocaml-base64 Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-batteries Updated package to latest version, 2.5.3. Changes include: 2016-12-30 11:21:47 +00:00
ocaml-cmdliner Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-cppo Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-deriving-ocsigen Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-extlib Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-findlib ocaml-findlib: make PLIST entry for 64bit platforms only 2017-04-24 21:47:47 +00:00
ocaml-js-build-tools Bump PKGREVISION for SunOS md5sum fix. 2017-05-18 12:37:04 +00:00
ocaml-lwt Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-oasis Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-odn Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-optcomp Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-ppx_core Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-ppx_deriving Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-ppx_driver Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-ppx_optcomp Added two uncommitted patches & increased revision. 2017-01-04 00:10:43 +00:00
ocaml-ppx_sexp_conv Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-ppx_tools Updated package to newest version. No major changes, but the package is now 2016-12-30 11:30:34 +00:00
ocaml-ppx_type_conv Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-re Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-react Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-reactiveData Updated package to latest version, 0.2.1. Changes include: 2016-12-30 11:33:50 +00:00
ocaml-result Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-sexplib Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocaml-type_conv Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocamlbuild Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocamlgraph Revbump after icu update 2017-04-22 21:03:07 +00:00
ocamlify Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ocamlmod Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
ode
ogre
okteta Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
omake Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
opal Recursive bump for libvpx shlib major change. 2017-01-16 23:45:10 +00:00
open-vcdiff build fix for recent c++ compilers. 2017-05-31 22:32:52 +00:00
opencm
opengrok Revbump after icu update 2017-04-22 21:03:07 +00:00
openocd
openrcs Fixed pkglint warnings. 2016-12-17 13:33:08 +00:00
orc
ossp-uuid
p5-accessors Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-accessors-fast These packages all require the PERL_USE_UNSAFE_INC hack. 2017-06-28 13:24:28 +00:00
p5-Acme-Damn Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Acme-PlayCode Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Algorithm-Annotate Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Algorithm-C3 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Algorithm-CheckDigits Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Algorithm-Dependency Fix build with Perl 5.26.0 2017-06-06 23:58:52 +00:00
p5-Algorithm-Diff Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Algorithm-HowSimilar Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Algorithm-Merge Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Algorithm-Permute Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-aliased Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Alien-Packages Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-AnnoCPAN-Perldoc Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Any-Moose Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-AnyEvent Updated devel/p5-AnyEvent to 7.14 2017-06-25 05:09:18 +00:00
p5-AnyEvent-AIO Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-AnyEvent-IRC Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-AnyEvent-RabbitMQ Fix build using perl 5.26 2017-06-12 12:21:18 +00:00
p5-AnyEvent-XMPP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-App-Cache Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-App-CLI Fix build using perl 5.26 2017-06-12 12:21:18 +00:00
p5-App-Cmd Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-App-cpanminus Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-App-cpanoutdated Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-App-FatPacker Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-App-perlbrew Requires PERL_USE_UNSAFE_INC hack. 2017-06-15 11:52:41 +00:00
p5-App-Prove-Plugin-ProgressBar Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-App-Prove-Plugin-ProgressBar-Each Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-AppConfig Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-AppConfig-Std Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Array-Compare Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Array-Diff Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Array-RefElem Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-asa Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Async-Interrupt Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-AtExit Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Attribute-Lexical Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-autobox Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-autobox-Core Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Autodia Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-autodie Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-AutoLoader Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-autovivification Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-AutoXS-Header Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-B-Compiling Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-B-Hooks-EndOfScope Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-B-Hooks-OP-Annotation Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-B-Hooks-OP-Check Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-B-Hooks-OP-Check-EntersubForCV Fix build using perl 5.26 2017-06-12 12:21:18 +00:00
p5-B-Hooks-OP-Check-StashChange Fix build using perl 5.26 2017-06-12 12:21:18 +00:00
p5-B-Hooks-OP-PPAddr Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-B-Hooks-Parser Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-B-Keywords Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-B-Utils Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-BackPAN-Index Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-bareword-filehandles Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Bit-Vector Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-boolean Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-BSD-Resource Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Cache Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Cache-Cache Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Cache-FastMmap Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Cache-LRU Fix build using perl 5.26 2017-06-12 12:21:18 +00:00
p5-Cache-Memcached Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Cache-Simple-TimedExpiry Fix build with Perl 5.26.0 2017-06-06 14:45:48 +00:00
p5-Canary-Stability Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-capitalization Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Capture-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Carp Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Carp-Always Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Carp-Assert Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Carp-Assert-More Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Carp-Clan Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Carp-REPL Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Check-ISA Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CHI Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-circular-require Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-CLASS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Accessor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Accessor-Chained Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Accessor-Grouped Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Class-Accessor-Lite Fix build with Perl 5.26.0 2017-06-06 14:58:09 +00:00
p5-Class-Accessor-Named Fix build using perl 5.26 2017-06-12 12:21:18 +00:00
p5-Class-Adapter Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Class-Autouse Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Class-Base Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-C3 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-C3-Adopt-NEXT Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-C3-Componentised Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Class-C3-XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Container Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Data-Accessor Fix build using perl 5.26 2017-06-12 12:21:18 +00:00
p5-Class-Data-Inheritable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-ErrorHandler Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Factory Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Factory-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Field Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Fields Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Gomor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Inner Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-InsideOut Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Inspector Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-ISA Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Load Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Load-XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Loader Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-MakeMethods Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Method-Modifiers Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-MethodMaker Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Mix Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-ObjectTemplate Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-OOorNO Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-ReturnValue Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Class-Singleton Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Std Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Throwable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Trigger Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Class-Unload Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-Virtual Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-WhiteHole Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-XML Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-XPath Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Class-XSAccessor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Clone Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Clone-Fast Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Clone-PP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-common-sense Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Compress-PPMd Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Compress-Raw-Bzip2 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Compress-Raw-Zlib Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-Any Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-Any-Merge Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-Auto Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-AutoConf Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-File Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-Find Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-General Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-GitLike Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Config-Grammar Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-INI Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-INI-Reader-Ordered Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-IniFiles Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-MVP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-MVP-Reader-INI Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-Properties Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-Std Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Config-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Const-Fast Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-constant-def These packages all require the PERL_USE_UNSAFE_INC hack. 2017-06-28 08:27:40 +00:00
p5-Context-Preserve Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Contextual-Return Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Convert-Binary-C Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Changes Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Checksums Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-DistnameInfo Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-FindDependencies Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Inject Requires PERL_USE_UNSAFE_INC hack. 2017-06-15 11:52:41 +00:00
p5-CPAN-Meta Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Meta-Check Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Meta-Requirements Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Meta-YAML Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Mini Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-ParseDistribution Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Perl-Releases Updated devel/p5-CPAN-Perl-Releases to 3.22 2017-06-10 05:52:29 +00:00
p5-CPAN-Reporter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPAN-Uploader Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-CPANPLUS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Curses Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Curses-UI Requires PERL_USE_UNSAFE_INC hack. 2017-06-15 11:52:41 +00:00
p5-Curses-UI-POE Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Alias Requires PERL_USE_UNSAFE_INC hack. 2017-06-14 15:46:52 +00:00
p5-Data-Buffer Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Compare Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Denter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Dump Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Dump-Streamer Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Dumper Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Dumper-Concise Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Dumper-Names Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-GUID Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Hierarchy Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Integer Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-MessagePack Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Data-Munge Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-ObjectDriver Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-OptList Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Page Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Page-Pageset Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Pageset Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Peek Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Printer Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Random Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Data-Record Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Section Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Section-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Serializer Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-ShowTable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Stag Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Structure-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Taxi Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-TemporaryBag Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Uniqid Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-UUID Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Data-Visitor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Date-Business Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Date-Calc Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Date-Calc-XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Date-Manip Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Date-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Debug-Client Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Debug-ShowStuff Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Declare-Constraints-Simple Fix build with Perl 5.26.0 2017-06-06 23:58:52 +00:00
p5-Devel-Autoflush Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-BeginLift Requires PERL_USE_UNSAFE_INC hack. 2017-06-14 15:53:52 +00:00
p5-Devel-Caller Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-CheckBin Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-CheckCompiler Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-CheckLib Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-CheckOS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Confess Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Cover Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Cycle Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Declare Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Dumpvar Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Devel-ebug Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-EvalContext Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Events Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Events-Objects Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-FindPerl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-FindRef Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Gladiator Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-GlobalDestruction Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Hide Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Leak-Object Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Devel-LexAlias Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-NYTProf Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-OverloadInfo Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-PartialDump Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-PatchPerl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-PPPort Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Pragma Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Profile Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Refactor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Refcount Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-REPL Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Size Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-SmallProf Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-StackTrace Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-StackTrace-AsHTML Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-StackTrace-WithLexicals Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Devel-Symdump Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-Trace Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Devel-TraceUse Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Dir-Self Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Dist-CheckConflicts Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Dist-Zilla Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Dist-Zooky Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-enum Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Env-Path Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Error Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-EV Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Eval-Closure Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Eval-LineNumbers Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Event Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Event-ExecFlow Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Event-RPC Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ex-lib Requires PERL_USE_UNSAFE_INC hack. 2017-06-14 16:11:19 +00:00
p5-Exception-Class Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Exception-Handler Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Expect Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Expect-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-experimental Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Exporter-Lite Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Exporter-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-AutoInstall Fix build with Perl 5.26.0 2017-06-06 23:58:52 +00:00
p5-ExtUtils-CBuilder Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-Command Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-Config Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-CppGuess Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-Depends Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-F77 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-Helpers Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-InstallPaths Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-LibBuilder Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-MakeMaker Updated devel/p5-ExtUtils-MakeMaker to 7.30 2017-06-15 14:10:11 +00:00
p5-ExtUtils-MakeMaker-Coverage Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-MakeMaker-CPANfile Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-Manifest Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-ModuleMaker Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-ModuleMaker-TT Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-ParseXS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-PkgConfig Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-XSBuilder Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-ExtUtils-XSpp Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-BaseDir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Binary Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-BOM Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-ChangeNotify Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-chdir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-ConfigDir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-DesktopEntry Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-DirCompare Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-DirSync Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Find-Object Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Find-Rule Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Find-Rule-Age Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Find-Rule-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Find-Rule-Permissions Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Find-Rule-PPI Requires PERL_USE_UNSAFE_INC hack. 2017-06-14 16:11:19 +00:00
p5-File-Find-Rule-VCS Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-File-Flat Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-File-Flock Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-FlockDir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-HomeDir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-LibMagic Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Listing Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-MimeInfo Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Modified Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Next Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-NFSLock Fix build with Perl 5.26.0 2017-06-07 23:49:25 +00:00
p5-File-Path Updated devel/p5-File-Path to 2.14 2017-06-10 05:13:02 +00:00
p5-File-Path-Expand Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Path-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-PathConvert Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Policy Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-pushd Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Save-Home Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Share Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-ShareDir Updated p5-File-ShareDir to 1.104. 2017-07-04 08:56:30 +00:00
p5-File-ShareDir-Install Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-ShareDir-ProjectDistDir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Slurp Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Slurp-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Slurper Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Temp Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Tempdir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Touch Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Type Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-File-Which Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-FileHandle-Fmode Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-FileHandle-Unget Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Filesys-Notify-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Find-Lib Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-FindBin-libs Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-forks Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Format-Human-Bytes Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-FreezeThaw Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Function-Parameters Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Future Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Getopt-ArgvFile Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Getopt-Euclid Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Getopt-Long Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Getopt-Long-Descriptive Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Getopt-Mixed Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Getopt-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Getopt-Tabular Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-gettext Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Git-CPAN-Patch Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Git-Repository Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Git-Repository-Plugin-AUTOLOAD Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Git-Version-Compare Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Git-Wrapper Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-GitLab-API-v3 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Glib-Object-Introspection Updated devel/p5-Glib-Object-Introspection to 0.043 2017-06-12 13:14:31 +00:00
p5-glib2 Fix build with Perl 5.26.0 2017-06-08 00:17:24 +00:00
p5-Gnome2 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Gnome2-GConf Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Graph Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Graph-ReadWrite Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Gravatar-URL Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Gtk2-GladeXML Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Guard Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Hash-Case Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Hash-FieldHash Fix build with Perl 5.26.0 2017-06-08 12:57:15 +00:00
p5-Hash-Flatten Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Hash-Merge Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Hash-Merge-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Hash-MoreUtils Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Hash-MultiValue Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Hash-Util-FieldHash-Compat Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Heap Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Hook-LexWrap Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IMDB-Film Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Import-Into Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Importer Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-inc Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-inc-latest Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-indirect Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Inline Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Inline-C Updated devel/p5-Inline-C to 0.78 2017-06-12 13:32:07 +00:00
p5-InlineX-C2XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Internals Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-AIO Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-All Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Async Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Capture Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-CaptureOutput Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Compress Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Digest Requires PERL_USE_UNSAFE_INC hack. 2017-06-14 16:11:19 +00:00
p5-IO-Event Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Handle-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-HTML Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-InSitu Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Interactive Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-LockedFile Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Multiplex Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Null Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Pager Updated devel/p5-IO-Pager to 0.39 2017-06-12 13:17:10 +00:00
p5-IO-Pipeline Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-IO-Pipely Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Prompt Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Prompter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-String Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-stringy Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Stty Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Tee Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-TieCombine Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Tty Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IO-Zlib Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-Cache Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-Cmd Updated devel/p5-IPC-Cmd to 0.98 2017-06-12 13:27:02 +00:00
p5-IPC-DirQueue Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-PubSub Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-IPC-Run Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-Run3 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-Shareable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-SharedCache Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-ShareLite Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-Signal Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-System-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-IPC-SysV Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-LDAP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-LEOCHARRE-CLI2 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-LEOCHARRE-Debug Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-LEOCHARRE-Dir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Lexical-Persistence Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Lexical-SealRequireHints Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-lib-abs Fix build with perl 5.26 2017-06-12 07:30:16 +00:00
p5-List-AllUtils Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-List-MoreUtils Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-List-Pairwise Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-List-SomeUtils devel/p5-List-SomeUtils to 0.54 2017-06-12 13:34:46 +00:00
p5-List-SomeUtils-XS Updated devel/p5-List-SomeUtils-XS to 0.53 2017-06-15 14:12:55 +00:00
p5-List-UtilsBy Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-local-lib Updated devel/p5-local-lib from 2.000019 to to 2.000023 2017-06-18 03:41:19 +00:00
p5-Locale-Msgfmt Fix build using perl 5.26 2017-06-12 12:02:13 +00:00
p5-Locale-PO Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Agent Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Any Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Any-Adapter-Callback Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Any-Adapter-Dispatch Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Any-Adapter-Log4perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Any-Adapter-Screen Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Any-Adapter-TAP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Dispatch Updated devel/p5-Log-Dispatch to 2.65 2017-06-15 14:16:29 +00:00
p5-Log-Dispatch-Array Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Dispatch-Config Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Dispatch-DBI Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Dispatch-FileRotate Updated devel/p5-Log-Dispatch-FileRotate to 1.26 2017-06-12 13:41:13 +00:00
p5-Log-Dispatch-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Dispatchouli Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Handler Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Log4perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-LogLite Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Message Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Message-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Report Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Report-Optional Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Log-Trace Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Mac-Carbon Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Mac-SystemDirectory Fix build with Perl 5.26.0. 2017-06-07 22:29:41 +00:00
p5-Make Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Memoize Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Memoize-ExpireLRU Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Memoize-Memcached Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MetaCPAN-API Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MetaCPAN-Client Updated devel/p5-MetaCPAN-Client to 2.016 2017-06-12 13:51:53 +00:00
p5-Method-Signatures Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Method-Signatures-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Mixin-ExtraFields Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Mixin-ExtraFields-Param Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Mixin-Linewise Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Mo Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Modern-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Build Updated devel/p5-Module-Build to 0.42240 2017-06-15 14:22:58 +00:00
p5-Module-Build-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Build-WithXSpp Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Build-XSUtil Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-CoreList Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-CPANfile Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-CPANTS-Analyse Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Dependency Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-ExtractUse Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Find Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Implementation Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Install Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Install-AuthorRequires Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Module-Install-AuthorTests Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Module-Install-GithubMeta Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Install-ManifestSkip Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Install-PadrePlugin Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Install-ReadmeFromPod Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Install-Repository Fix build with perl 5.26 2017-06-12 12:30:06 +00:00
p5-Module-Install-RTx Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Install-Substitute Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Install-XSUtil Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Load Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Manifest Fix build using perl 5.26 2017-06-12 12:02:13 +00:00
p5-Module-Manifest-Skip Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Metadata Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Pluggable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Refresh Fix build with Perl 5.26.0 2017-06-06 14:58:09 +00:00
p5-Module-Runtime Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Runtime-Conflicts Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-ScanDeps Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Starter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Starter-PBP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Versions Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Module-Versions-Report Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Mojo-IOLoop-ForkCall Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Moo Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Moos Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Moose Updated devel/p5-Moose to 2.2005 2017-06-18 03:30:35 +00:00
p5-Moose-Autobox Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Moose-Policy Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Aliases Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-App Updated devel/p5-MooseX-App to 1.38 2017-06-17 13:39:11 +00:00
p5-MooseX-App-Cmd Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Attribute-Chained Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-AttributeHelpers Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Attributes-Curried Fix build with perl 5.26 2017-06-12 12:40:17 +00:00
p5-MooseX-ClassAttribute Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-CompileTime-Traits Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-ConfigFromFile Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Daemonize Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Declare Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Emulate-Class-Accessor-Fast Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-MooseX-FollowPBP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Getopt Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Has-Options Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-InsideOut Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-LazyRequire Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-MarkAsMethods Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Meta-TypeConstraint-ForceCoercion Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Method-Signatures Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-MethodAttributes Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-MultiInitArg Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-NonMoose Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Object-Pluggable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-OneArgNew Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Param Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Params-Validate Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-POE Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Role-Parameterized Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Role-Tempdir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Role-WithOverloading Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-SemiAffordanceAccessor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-SetOnce Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-SimpleConfig Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Singleton Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-StrictConstructor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Traits Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooseX-Traits-Pluggable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooseX-Types Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooseX-Types-Common Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooseX-Types-JSON Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooseX-Types-LoadableClass Updated devel/p5-MooseX-Types-LoadableClass to 0.015 2017-06-18 03:33:24 +00:00
p5-MooseX-Types-LogAny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooseX-Types-Path-Class Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooseX-Types-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooseX-Types-Stringlike Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooseX-Types-Structured Updated devel/p5-MooseX-Types-Structured to 0.36 2017-06-17 13:26:53 +00:00
p5-MooseX-Types-URI Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MooX-ClassAttribute Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-Cmd Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-ConfigFromFile Updated devel/p5-MooX-ConfigFromFile to 0.008 2017-06-18 03:22:26 +00:00
p5-MooX-File-ConfigDir Updated devel/p5-MooX-File-ConfigDir to 0.006 2017-06-18 03:24:59 +00:00
p5-MooX-HandlesVia Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-late Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-Log-Any Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-Options Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-Roles-Pluggable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-StrictConstructor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-Types-MooseLike Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-MooX-Types-MooseLike-Numeric Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-Mouse Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MouseX-Getopt Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-MouseX-NativeTraits Fix build with perl 5.26 2017-06-12 12:40:17 +00:00
p5-MouseX-Types Fix build with perl 5.26. indentation 2017-06-12 12:42:04 +00:00
p5-MouseX-Types-Path-Class These packages all require the PERL_USE_UNSAFE_INC hack. 2017-06-28 08:27:40 +00:00
p5-MRO-Compat Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:22:16 +00:00
p5-multidimensional Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-namespace-autoclean Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-namespace-clean Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Net-CIDR Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Net-LDAP-Batch Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Net-LDAP-Class Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Net-LDAP-Server-Test Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Net-LDAP-SID Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Net-Netmask Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-NEXT Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Object-Accessor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Object-Declare Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Object-Event Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Object-InsideOut Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Object-Pluggable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Object-Realize-Later Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Object-Signature Requires PERL_USE_UNSAFE_INC hack. 2017-06-15 11:40:10 +00:00
p5-OLE-Storage_Lite Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-OOTools Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Ouch Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Package-Constants Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Package-DeprecationManager Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Package-Generator Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Package-Stash Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Package-Stash-XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Package-Variant Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PadWalker Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-pango Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-PAR Update p5-PAR from 1.011 to 1.015 2017-06-18 03:14:22 +00:00
p5-PAR-Dist Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Parallel-ForkManager Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Parallel-Prefork Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Params-Classify Fix build with Perl 5.26.0 with rt.cpan.org patch 2017-06-06 14:38:05 +00:00
p5-Params-Coerce Fix build with Perl 5.26.0 2017-06-06 23:58:52 +00:00
p5-Params-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Params-Validate Updated p5-Params-Validate to 1.29. 2017-06-14 13:32:40 +00:00
p5-Params-ValidationCompiler Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-parent Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Parse-CPAN-Meta Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Parse-CPAN-Packages Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Parse-ErrorString-Perl Fix build with perl 5.26 2017-06-12 08:36:37 +00:00
p5-Parse-ExuberantCTags Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Parse-Method-Signatures Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Parse-RecDescent Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Parse-Yapp Updated devel/p5-Parse-Yapp to 1.06 2017-06-17 13:09:33 +00:00
p5-PatchReader Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Path-Class Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Path-Class-File-Stat Fix build with perl 5.26 2017-06-12 08:36:37 +00:00
p5-Path-Dispatcher Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Path-Dispatcher-Declarative Fix build with perl 5.26 2017-06-12 08:36:37 +00:00
p5-Path-FindDev Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Path-IsDev Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PathTools Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Pegex Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl-APIReference Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl-Critic Updated devel/p5-Perl-Critic to 1.128 2017-06-17 13:04:16 +00:00
p5-perl-headers Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Perl-MinimumVersion Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl-PrereqScanner Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl-Tidy Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl-Version Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl4-CoreLibs Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl6-Export Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl6-Export-Attrs Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl6-Junction Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Perl6-Slurp Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PerlIO-eol Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PerlIO-gzip Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PerlIO-utf8_strict Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PerlIO-via-Bzip2 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PerlIO-via-dynamic Fix build with perl 5.26 2017-06-12 08:36:37 +00:00
p5-PerlIO-via-symlink Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PerlIO-via-Timeout Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PHP-Serialization Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-pip These packages all require the PERL_USE_UNSAFE_INC hack. 2017-06-28 08:27:40 +00:00
p5-Pod-Usage Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-POE Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-POE-Component-Cron Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-POE-Component-Pluggable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-POE-Component-Schedule Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-POE-Component-Syndicator Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-POE-Test-Loops Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-POEx-Types Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PPI Updated devel/p5-PPI to 1.224 2017-06-13 12:19:04 +00:00
p5-PPI-PowerToys Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PPI-XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PPIx-Regexp Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PPIx-Utilities Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-prefork Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Probe-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-Background Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-Daemon Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-InvokeEditor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-PID-File Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-Pidfile Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-ProcessTable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-Queue Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-Wait3 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Proc-WaitStat Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-PV Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Python-Serialise-Marshal Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Readonly Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Readonly-XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Ref-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Ref-Util-XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Regexp-Assemble Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Regexp-MatchContext Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Regexp-Parser Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Regexp-Shellish Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Reply Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Return-MultiLevel Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Return-Value Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Role-Basic Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Role-HasMessage Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Role-Identifiable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Role-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Rose-Object Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-RT-Authen-ExternalAuth Fix build with perl 5.26 2017-06-12 08:36:37 +00:00
p5-Safe-Hole Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Safe-Isa Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Scalar-Defer Fix build with perl 5.26 2017-06-12 08:36:37 +00:00
p5-Scalar-List-Utils Updated p5-Scalar-List-Utils to 1.48. 2017-06-25 07:10:19 +00:00
p5-Scalar-Util-Refcount Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Schedule-RateLimiter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Scope-Guard Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Scope-Upper Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-SDL Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Search-Elasticsearch Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Set-Array Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Set-IntSpan Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Set-Object Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Set-Scalar Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Shell-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-ShipIt Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Signal-Mask Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-signatures Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Smart-Comments Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Software-License Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sort-Maker Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sort-Naturally Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sort-Versions Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Specio Updated p5-Specio to 0.38. 2017-07-04 09:00:10 +00:00
p5-Spiffy Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Spoon Fix build with perl 5.26 the dirty way. 2017-06-12 06:57:34 +00:00
p5-Storable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Stream-Buffered Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-strictures Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-String-Escape Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-String-Format Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-String-PerlIdentifier Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-String-Print updated devel/p5-String-Print from 0.15 to 0.90 2017-06-17 13:44:42 +00:00
p5-String-Util Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Struct-Dumb Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Exporter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Exporter-ForMethods Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Exporter-GlobExporter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Exporter-Progressive Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Identify Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Info Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Install Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Installer Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Name Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Override Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sub-Quote Updated p5-Sub-Quote to 2.004000. 2017-06-14 13:35:23 +00:00
p5-Sub-Uplevel Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-subversion Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-SUPER Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-SVN-Class Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-SVN-Dump Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-SVN-Mirror Fix build with perl 5.26 2017-06-12 08:36:37 +00:00
p5-SVN-Notify Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-SVN-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Symbol-Global-Name Fix build with Perl 5.26.0 2017-06-06 23:58:52 +00:00
p5-syntax Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Syntax-Keyword-Junction Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Sys-Syscall Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-System-Command Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-TAP-Formatter-HTML Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-TAP-Harness-Archive Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Task-Weaken Fix build with Perl 5.26.0 2017-06-06 23:58:52 +00:00
p5-Tee Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Template-Plugin-Handy Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Template-Plugin-HashMerge Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Template-Plugin-ListMoreUtils Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Template-Plugin-ListUtil Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Template-Plugin-VMethods Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Animation Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ANSIColor Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Cap Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Encoding Fix build with perl 5.26 the dirty way 2017-06-12 07:02:24 +00:00
p5-Term-ProgressBar Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ProgressBar-Quiet Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ProgressBar-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Prompt Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ReadKey Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ReadLine Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ReadLine-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ReadLine-TTYtter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ReadPassword Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Screen Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Shell Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-ShellUI Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Size Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Size-Any Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Size-Perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-Table Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Term-UI Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Aggregate Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-API Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Approx Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Assertions Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Base Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-BDD-Cucumber Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-CheckDeps Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-CheckManifest Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Class Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-ClassAPI Fix build with Perl 5.26.0 2017-06-06 23:58:52 +00:00
p5-Test-CleanNamespaces Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Cmd Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Command-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Compile Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Continuous Fix build with perl 5.26 the dirty way 2017-06-12 07:20:58 +00:00
p5-Test-CPAN-Meta Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-CPAN-Meta-YAML Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Deep Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-DependentModules Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Differences Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Dir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-DistManifest Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Distribution Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-EOL Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Exception Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Expect Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-FailWarnings Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Fatal Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-File Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-File-Contents Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-File-ShareDir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Fixture-DBIC-Schema Fix build with perl 5.26 2017-06-12 13:26:45 +00:00
p5-Test-Harness Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-HexString Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Identity Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-InDistDir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Inline Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Test-Inter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Kwalitee Updated devel/p5-Test-Kwalitee to 1.26 2017-06-18 03:37:30 +00:00
p5-Test-LeakTrace Fix build with Perl 5.26.0 2017-06-06 14:22:36 +00:00
p5-Test-Log4perl Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-LongString Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Manifest Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Memory-Cycle Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-MinimumVersion Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Mock-LWP Fix build with perl 5.26 the dirty way 2017-06-12 07:20:58 +00:00
p5-Test-MockModule Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-MockObject Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Modern Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-More-Behaviour Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Most Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Needs Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-NoTabs Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-NoWarnings Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Object Fix build with perl 5.26 the dirty way 2017-06-12 07:20:58 +00:00
p5-Test-Output Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Perl-Critic Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Pod Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Pod-Coverage Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Pod-Spelling-CommonMistakes Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-POE-Client-TCP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-POE-Server-TCP Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Refcount Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Reporter Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Requires Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Requires-Git Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Roo Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Script Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Script-Run Fix build with perl 5.26 the dirty way 2017-06-12 07:20:58 +00:00
p5-Test-SharedFork Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Simple Updated p5-Test-Simple to 1.302086. 2017-06-25 07:09:08 +00:00
p5-Test-Spec Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:22 +00:00
p5-Test-Spelling Requires PERL_USE_UNSAFE_INC hack. 2017-06-14 16:11:19 +00:00
p5-Test-Stream Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-SubCalls Fix build with perl 5.26 the dirty way 2017-06-12 07:20:58 +00:00
p5-Test-Taint Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-TempDir Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-TempDir-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-TinyMocker Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-Toolbox Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-Trap Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-Unit Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-use-ok Fix build with Perl 5.26.0 2017-06-08 12:57:15 +00:00
p5-Test-UseAllModules Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-utf8 Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Test-Version Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-Warn Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-Warnings Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-Weaken Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-Without-Module Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-WWW-Selenium Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-YAML-Meta Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test-YAML-Valid Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
p5-Test2-Plugin-NoWarnings Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Test2-Suite Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-TheSchwartz Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Throwable Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-Array-AsHash Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-Array-Sorted Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-Cache Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-Cache-LRU Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-Cache-LRU-Expires Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-Cycle Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-Function Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-IxHash Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-LLHash Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-RefHash Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-RefHash-Weak Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-RegexpHash Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tie-ToObject Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tree-DAG_Node Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tree-R Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tree-Simple Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Tree-Simple-VisitorFactory Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Try-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-TryCatch Requires PERL_USE_UNSAFE_INC hack. 2017-06-14 16:16:34 +00:00
p5-Type-Tiny Updated devel/p5-Type-Tiny to 1.002001 2017-06-12 13:47:15 +00:00
p5-Type-Tiny-XS Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Types-Serialiser Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-UNIVERSAL-can Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-UNIVERSAL-isa Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-UNIVERSAL-moniker Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-UNIVERSAL-require Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-UUID-Tiny Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Variable-Magic Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-VCP These packages all require the PERL_USE_UNSAFE_INC hack. 2017-06-28 08:27:40 +00:00
p5-VCP-Dest-svk These packages all require the PERL_USE_UNSAFE_INC hack. 2017-06-28 13:24:28 +00:00
p5-version Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Want Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-WeakRef Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-Wx-Perl-DataWalker Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
p5-XSLoader Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
palmpower
pango Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
pangomm Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
pangox-compat Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
papaya
pardiff
patch
patchelf
patchutils
pcc-libs Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
pccts
pcl-cvs
pcre patches for CVE-2017-7186 from upstream 2017-06-10 18:02:12 +00:00
pcre++
pcre-ocaml Recursive revbump associated with ocaml update to 4.04. 2016-12-30 11:16:56 +00:00
pcre2 Updated pcre2 to 10.23. 2017-02-20 09:44:34 +00:00
pdcurses
pear-Console_CommandLine
pedisassem
phabricator Phabricator doesn't support PHP-7.0. 2017-06-27 10:35:46 +00:00
php-gettext
php-gmp
php-igbinary
php-libawl Update php-libawl to 0.57. 2017-06-05 16:01:56 +00:00
php-memcache
php-memcached
php-mode
php-opcache
php-pcntl
php-posix
php-pthreads Make option checking match other places. 2016-12-31 09:23:06 +00:00
php-raphf
php-raphf2
php-shmop
php-sysvmsg
php-sysvsem
php-sysvshm
php-xcache
php-xdebug Update php-xdebug to 2.5.4. 2017-05-28 11:35:30 +00:00
physfs
picasm
picopb
picp fix include on sunos 2017-06-27 23:50:24 +00:00
picprg
pilrc
pipestatus
pkg-config Updated devel/pkg-config to 0.29.2 2017-05-05 01:19:35 +00:00
pkgconf This uses libtool. 2017-05-29 13:23:41 +00:00
ply
pmccabe
poco
polly Mark c++11 requirement 2017-05-06 01:38:43 +00:00
popt
poxml Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
prcs
ProjectCenter Revbump after icu update 2017-04-22 21:03:07 +00:00
protobuf Disable Solaris ISA selection. 2017-07-01 15:26:52 +00:00
protobuf-c
pstreams
psvn
pth
pthread-sem
pthread-stublib
ptlib
pvs
pwlib
py-apipkg With apipkg you can control the exported namespace of a python package and 2017-05-29 10:38:16 +00:00
py-appdirs BOOTSTRAP_SETUPTOOLS is not necessary any longer. 2017-06-01 13:31:45 +00:00
py-argcomplete Update devel/py-argcomplete to 1.8.2. 2017-01-27 14:28:12 +00:00
py-argh 0.26.2: 2017-06-21 10:27:55 +00:00
py-argparse argparse 1.4.0 2017-04-06 06:33:57 +00:00
py-astor
py-astroid Update devel/py-astroid to 1.4.9. 2017-02-28 17:15:24 +00:00
py-at-spi Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-at-spi2 Update py-at-spi2 to 2.20.3 2017-01-25 16:37:57 +00:00
py-atomicwrites
py-atpublic Import atpublic 0.5 as devel/py-atpublic. 2017-04-25 17:06:38 +00:00
py-attrs Changes 17.2.0: 2017-05-24 19:41:34 +00:00
py-automat Changes 0.6.0: 2017-05-20 06:11:21 +00:00
py-babel Version 2.4.0 2017-04-06 06:49:18 +00:00
py-backports.functools_lru_cache Import functools_lru_cache 1.3 as devel/py-backports.functools_lru_cache. 2017-02-28 20:47:57 +00:00
py-backports.shutil_get_terminal_size Add py-backports.shutil_get_terminal_size 1.0.0 2017-04-23 04:32:41 +00:00
py-backports_abc Changes 0.5: 2017-04-05 17:58:25 +00:00
py-binaryornot
py-blessings Blessings lifts several of curses' limiting assumptions, and it makes your 2017-04-12 11:41:44 +00:00
py-blinker
py-boost Changes 1.64.0: 2017-04-29 18:31:42 +00:00
py-bugzilla Add py-bugzilla-2.1.0: 2017-04-03 14:32:09 +00:00
py-buildbot Update python 3.x status after py-twisted now supports 3.x. 2017-02-14 10:26:27 +00:00
py-buildbot-slave Update python 3.x status after py-twisted now supports 3.x. 2017-02-14 10:26:27 +00:00
py-cached-property Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-cachetools Import py-cachetools-2.0.0 2017-03-20 19:56:55 +00:00
py-capstone
py-cffi Use libffi's closure handling based on code from the upstream branch. 2017-07-03 18:17:45 +00:00
py-characteristic
py-checker Use "${MV} || ${TRUE}" and "${RM} -f" consistently in post-install targets. 2017-01-03 13:23:01 +00:00
py-cheetah Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-click Fix test target. 2017-05-17 11:20:55 +00:00
py-click-log
py-click-threading
py-codestyle Changes 2.3.1: 2017-05-03 19:29:58 +00:00
py-compizconfig Revbump after icu update 2017-04-22 21:03:07 +00:00
py-configargparse 0.12.0: 2017-06-21 09:44:54 +00:00
py-configobj
py-configparser Import configparser 3.5.0 as devel/py-configparser. 2017-02-28 20:51:28 +00:00
py-constantly Import py-constantly-15.1.0 as devel/py-constantly. 2016-11-30 12:24:34 +00:00
py-constants
py-construct USE_LANGUAGES is not needed 2017-06-21 09:53:50 +00:00
py-cookiecutter
py-coverage Version 4.4.1 2017-05-17 11:39:58 +00:00
py-cparser
py-cubes Cubes is a light-weight Python framework and set of tools for Online Analytical 2017-06-01 12:05:28 +00:00
py-curses Fix prior patches to use is_pad(3) rather than is_keypad(3). 2017-01-05 23:16:42 +00:00
py-cursespanel Build py-cursespanel with support for NetBSD curses. 2017-01-02 21:01:34 +00:00
py-curtsies Curtsies is a Python 2.6+ & 3.3+ compatible library for interacting with 2017-04-12 11:42:45 +00:00
py-cyordereddict Fix py-cyordereddict's PLIST for python27 2017-04-14 00:40:29 +00:00
py-cython Changes 0.25.2: 2017-01-25 16:09:06 +00:00
py-d2to1 Update to 0.2.12. Changes: 2017-01-11 23:55:32 +00:00
py-daemon Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-daemonize
py-darcsver Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-ddt Import ddt 1.1.1 as devel/py-ddt. 2017-04-25 20:37:06 +00:00
py-decorator Updated py-decorator to 4.0.11. 2017-01-16 08:04:48 +00:00
py-dialog Updated devel/py-dialog to 3.4.0 2016-11-13 10:52:28 +00:00
py-dialog2 Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-distorm3 Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-docopt
py-docstyle Import py-docstyle-1.1.1 as devel/py-docstyle. 2017-04-04 13:31:37 +00:00
py-doctor Update python 3.x status after py-twisted now supports 3.x. 2017-02-14 10:26:27 +00:00
py-dogpile-cache Import py-dogpile-cache-0.6.2 as devel/py-dogpile-cache 2017-04-14 13:53:25 +00:00
py-dulwich Updated py-dulwich to 0.17.2. 2017-04-19 17:25:08 +00:00
py-editorconfig-core Import py-editorconfig-core-0.12.1 as devel/py-editorconfig-core 2017-04-14 12:18:31 +00:00
py-entrypoints Add py-entrypoints 0.2.2 2017-04-23 05:13:03 +00:00
py-enum
py-enum34
py-execnet Needs setuptools_scm. 2017-05-30 20:31:11 +00:00
py-expect Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-expressions Arithmetic expression parser library. Embed customized expression evaluation 2017-06-01 12:05:09 +00:00
py-extras Updated py-extras to 1.0.0. 2017-02-22 13:48:44 +00:00
py-faker Deal with lack of Python 3.x support in Python 2.7. 2017-06-17 19:37:12 +00:00
py-falcon Changelog for Falcon 1.2.0 2017-05-21 06:54:13 +00:00
py-fann2
py-fastimport Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-filebytes
py-filechunkio Changes 1.8: 2017-05-18 06:53:48 +00:00
py-fixtures Import py-fixtures-3.0.0 as devel/py-fixtures. 2017-02-22 14:02:49 +00:00
py-flake8 Added dependencies for Python 2.7 2017-06-09 13:57:54 +00:00
py-flake8-import-order Import py-flake8-import-order-0.12 as devel/py-flake8-import-order. 2017-04-04 14:41:03 +00:00
py-flake8-polyfill Import py-flake8-polyfill-1.0.1 as devel/py-flake8-polyfill. 2017-04-04 14:07:09 +00:00
py-flakes Update to 1.5.0 2017-02-13 11:08:25 +00:00
py-flexmock
py-flufl.i18n Import flufl.i18n 1.1.3 as devel/py-flufl.i18n. 2017-04-25 20:19:28 +00:00
py-flufl.lock Import flufl.lock 2.4.1 as devel/py-flufl.lock. 2017-04-25 20:21:48 +00:00
py-flufl.testing Import flufl.testing 0.7 as devel/py-flufl.testing. 2017-04-26 10:16:43 +00:00
py-freezegun 0.3.9 2017-05-16 08:37:29 +00:00
py-funcparserlib
py-funcsigs
py-functools32 This is a backport of the functools standard library module from Python 3.2.3 2017-06-05 07:27:02 +00:00
py-future Add version suffix to binaries to allow multiple alternatives at once. 2017-02-06 01:06:05 +00:00
py-futures Update devel/py-futures to 3.1.1. 2017-04-18 15:39:19 +00:00
py-game Revert all but the conditional include of libX11 on Darwin. 2017-06-20 22:37:53 +00:00
py-generate
py-gflags Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-gitinspector Switch distutils.mk to egg.mk in py-gitinspector 2017-06-16 21:03:58 +00:00
py-gobject Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-gobject-shared
py-gobject3 Upate py-gobject3 to 3.22.0 2016-11-25 13:05:12 +00:00
py-gobject3-common
py-google-apputils Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-grako Use the build dependency I reported to actually fix the build. 2017-06-17 19:37:39 +00:00
py-greenlet Changes 0.4.12: 2017-04-12 11:40:08 +00:00
py-h5py
py-hash
py-hg-fastimport Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-hg-git Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-hglib
py-hglist Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-hgnested Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-hgtools
py-hgview Use "${MV} || ${TRUE}" and "${RM} -f" consistently in post-install targets. 2017-01-03 13:23:01 +00:00
py-hypothesis 3.11.6: 2017-06-20 07:26:10 +00:00
py-idle
py-incremental Incremental 17.5.0 (2017-05-20) 2017-05-24 11:36:07 +00:00
py-InlineEgg Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-intervaltree Import py-intervaltree-2.1.0 2017-03-20 21:59:04 +00:00
py-iowait
py-ipaddr Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-ipykernel Changes 4.6.1: 2017-05-04 20:28:33 +00:00
py-ipython IPython 5.4.1 2017-06-24 08:07:14 +00:00
py-ipython1
py-ipython010 Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-ipython013 Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-ipython_genutils Delete a redundant variable 2017-03-20 19:16:27 +00:00
py-iso-639 Add package py-iso-639 version 0.4.5 2017-02-25 02:38:59 +00:00
py-iso3166 Add new package py-iso3166. 2017-02-25 02:15:19 +00:00
py-isort Import isort 4.2.5 as devel/py-isort. 2017-02-28 20:54:09 +00:00
py-jaraco_util
py-jersey Add missing dependency on py-automat. 2017-02-14 10:23:36 +00:00
py-jupyter_client 5.1: 2017-06-24 08:17:00 +00:00
py-jupyter_core Add py-jupyter_core 4.3.0 2017-04-23 04:23:52 +00:00
py-kaitaistruct Import py-kaitaistruct-0.7 as devel/py-kaitaistruct 2017-04-14 12:31:06 +00:00
py-kjbuckets Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-kqueue Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-lama Import py-lama-7.3.3 as devel/py-lama. 2017-04-04 14:40:14 +00:00
py-lazr.config Import lazr.config 2.2 as devel/py-lazr.config. 2017-04-25 19:59:59 +00:00
py-lazr.delegates Deal with Python 3.x code in py27 build. 2017-06-17 19:38:10 +00:00
py-lazy-object-proxy Import py-lazy-object-proxy 1.2.2 based on wip/py-lazy-object-proxy. 2017-02-28 17:11:28 +00:00
py-libevent-rpcgen Libevent 2.1.8-stable, it contains openssl fixes for resetting fd and using 2017-02-15 17:34:37 +00:00
py-libmc
py-limits
py-line_profiler Import py-line_profiler-2.0 2017-03-17 21:30:35 +00:00
py-linecache2
py-lockfile
py-logan
py-logilab-astng
py-logilab-common Fix ALTERNATIVES, ride previous revision. 2017-02-28 17:07:32 +00:00
py-lupa Add support for Lua 5.1 and 5.2. Add "luajit" option (off by default). 2017-05-30 21:59:56 +00:00
py-macholib Use "${MV} || ${TRUE}" and "${RM} -f" consistently in post-install targets. 2017-01-03 13:23:01 +00:00
py-mako
py-mando Import py-mando-0.5 as devel/py-mando. 2017-04-04 13:47:09 +00:00
py-mccabe Updated py-mccabe to 0.6.1. 2017-02-05 19:11:41 +00:00
py-memcached 1.58 release: 2017-05-29 09:24:45 +00:00
py-mercurial Updated py-mercurial to 4.2.1. 2017-06-19 20:07:43 +00:00
py-minimock
py-mock
py-modulegraph Use "${MV} || ${TRUE}" and "${RM} -f" consistently in post-install targets. 2017-01-03 13:23:01 +00:00
py-more-itertools
py-msgpack Changes 0.4.8: 2017-05-11 11:12:44 +00:00
py-multipledispatch Clear USE_LANGUAGES for py-multipledispatch 2017-03-17 19:30:47 +00:00
py-multiprocessing Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-newt Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-nose
py-nose-exclude
py-nose2 Import nose2 0.6.5 as devel/py-nose2. 2017-04-25 20:14:26 +00:00
py-nosexcover
py-ode Extend SHA512 checksums to various files I have on my local distfile 2017-03-23 17:06:45 +00:00
py-olefile Import py-olefile-0.44 as devel/py-olefile 2017-01-31 14:04:02 +00:00
py-open-vcdiff Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-Optik Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-packaging BOOTSTRAP_SETUPTOOLS is not necessary any longer. 2017-06-01 13:31:45 +00:00
py-ParamUnittest Import py-ParamUnittest-0.2 as devel/py-ParamUnittest. 2017-04-04 13:41:23 +00:00
py-pathlib2 Import py-pathlib2-2.2.1 as devel/py-pathlib2. 2017-02-22 12:54:31 +00:00
py-pbr Updated py-pbr to 3.0.1. 2017-05-29 11:08:23 +00:00
py-pep8 1.7.0 (2016-01-12) 2017-06-01 06:36:02 +00:00
py-pexpect Version 4.2.1 2017-05-04 10:43:28 +00:00
py-pip Add comment why test target won't work. 2017-02-07 23:42:04 +00:00
py-pkgconfig
py-pkginfo Updated py-pkginfo to 1.4.1. 2016-11-14 14:19:54 +00:00
py-pluggy
py-ply
py-polib
py-pqueue Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-pretend
py-prompt_toolkit Changes 1.0.14: 2017-05-04 19:30:51 +00:00
py-proteus Switch py-dateutils to plain DEPENDS. 2017-02-20 17:00:35 +00:00
py-protobuf Adjust DEPENDS to reflect current reality and make it compatible with 2017-05-12 20:11:39 +00:00
py-py Changes 1.4.33: Clean up tox.ini and use tox-travis to run on Travis 2017-05-03 19:33:10 +00:00
py-py2app Use "${MV} || ${TRUE}" and "${RM} -f" consistently in post-install targets. 2017-01-03 13:23:01 +00:00
py-pydispatcher Added devel/py-pydispatcher version 2.0.5 2017-02-13 21:18:14 +00:00
py-pyev
py-pylint Update devel/py-pylint to 1.6.5. 2017-03-01 13:08:43 +00:00
py-pyobjc
py-pyobjc-core
py-pyobjc-framework-Accounts
py-pyobjc-framework-AddressBook
py-pyobjc-framework-AppleScriptKit
py-pyobjc-framework-AppleScriptObjC
py-pyobjc-framework-Automator
py-pyobjc-framework-CalendarStore
py-pyobjc-framework-CFNetwork
py-pyobjc-framework-Cocoa
py-pyobjc-framework-Collaboration
py-pyobjc-framework-CoreData
py-pyobjc-framework-CoreLocation
py-pyobjc-framework-CoreText
py-pyobjc-framework-CoreWLAN
py-pyobjc-framework-DictionaryServices
py-pyobjc-framework-DiskArbitration
py-pyobjc-framework-EventKit
py-pyobjc-framework-ExceptionHandling
py-pyobjc-framework-FSEvents
py-pyobjc-framework-InputMethodKit
py-pyobjc-framework-InstallerPlugins
py-pyobjc-framework-InstantMessage
py-pyobjc-framework-LatentSemanticMapping
py-pyobjc-framework-LaunchServices
py-pyobjc-framework-OpenDirectory
py-pyobjc-framework-PreferencePanes
py-pyobjc-framework-PubSub
py-pyobjc-framework-QTKit
py-pyobjc-framework-Quartz
py-pyobjc-framework-ScreenSaver
py-pyobjc-framework-ScriptingBridge
py-pyobjc-framework-SearchKit
py-pyobjc-framework-ServiceManagement
py-pyobjc-framework-Social
py-pyobjc-framework-StoreKit
py-pyobjc-framework-SyncServices
py-pyobjc-framework-SystemConfiguration
py-pyobjc-framework-WebKit
py-pyparsing BOOTSTRAP_SETUPTOOLS is not necessary any longer. 2017-06-01 13:31:45 +00:00
py-Pyro
py-pysvn Revbump after icu update 2017-04-22 21:03:07 +00:00
py-pytemplate Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-pyutil Update python 3.x status after py-twisted now supports 3.x. 2017-02-14 10:26:27 +00:00
py-queuelib Added devel/py-queuelib version 1.4.2 2017-02-13 21:15:41 +00:00
py-quixote Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-radare2
py-radon Install versioned radon binary. Bump PKGREVISION. 2017-04-04 14:33:24 +00:00
py-rauth Add py-rauth package. 2017-03-17 20:44:38 +00:00
py-readline
py-rednose
py-repoze.lru
py-requests 2.18.1: 2017-06-15 05:59:47 +00:00
py-requests-file 1.4.2: 2017-06-22 09:22:03 +00:00
py-requests-ftp Import py-request-ftp-0.3.1 as devel/py-request-ftp 2017-03-07 18:15:21 +00:00
py-requests-mock Add missing dependency on py-pdr. Bump revision. 2017-05-19 14:56:40 +00:00
py-requests-toolbelt Updated py-requests-toolbelt to 0.8.0. 2017-05-29 11:07:19 +00:00
py-rope Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-rply Update to latest release, 0.7.4. Depends on devel/py-appdirs now and 2017-01-11 23:59:00 +00:00
py-ruamel-base
py-ruamel-ordereddict Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-ruamel-yaml Adjust DEPENDS and PLIST 2017-04-23 15:52:33 +00:00
py-scandir Import py-scandir-1.5 as devel/py-scandir. 2017-02-22 12:58:20 +00:00
py-serpent Changes 1.16: 2017-02-13 21:59:10 +00:00
py-setuptools Updated py-setuptools to 36.0.1. 2017-06-01 13:30:03 +00:00
py-setuptools_scm v1.15.6 2017-06-16 07:02:32 +00:00
py-setuptools_trial Update python 3.x status after py-twisted now supports 3.x. 2017-02-14 10:26:27 +00:00
py-simplegeneric Add py-simplegeneric 0.8.1 2017-04-23 03:43:15 +00:00
py-singledispatch
py-sortedcontainers Import py-sortedcontainers-1.5.7 as devel/py-sortedcontainers 2017-02-08 04:47:04 +00:00
py-Spans Include egg.mk, not distutils.mk, as this package uses setuptools. 2017-05-21 10:09:47 +00:00
py-speaklater
py-spwd
py-stevedore This is not really Python 3.4 incompatible 2017-04-15 12:30:07 +00:00
py-stompclient Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-stsci.distutils
py-subprocess32 Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-subversion Revbump after icu update 2017-04-22 21:03:07 +00:00
py-subvertpy Revbump after icu update 2017-04-22 21:03:07 +00:00
py-sysctl
py-tabular Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-test Pytest 3.1.2 (2017-06-08) 2017-06-10 19:22:12 +00:00
py-test-cov Updated py-test-cov to 2.5.1. 2017-05-17 11:26:25 +00:00
py-test-mock BUILD_DEPEND on setuptools_scm for joerg. 2017-04-14 07:13:51 +00:00
py-test-runner Updated py-test-runner to 2.11.1. 2017-02-17 14:47:43 +00:00
py-test-xdist Needs py-setuptools_scm. 2017-06-06 17:34:32 +00:00
py-testpath Add py-testpath 0.3 2017-04-23 05:04:02 +00:00
py-testresources Import py-testresources-2.0.1 as devel/py-testresources. 2017-03-05 14:11:13 +00:00
py-testscenarios Import py-testscenarios-0.5.0 as devel/py-testscenarios. 2017-02-22 14:21:40 +00:00
py-testtools 2.3.0 2017-05-21 06:45:39 +00:00
py-thrift
py-tlsh
py-tortoisehg Updated py-tortoisehg to 4.2.1. 2017-06-19 20:11:39 +00:00
py-tox Update devel/py-tox to 2.7.0. 2017-04-26 13:25:29 +00:00
py-traceback2
py-traitlets python27 version requires py-enum34. 2017-04-23 04:18:47 +00:00
py-tryton Switch py-dateutils to plain DEPENDS. 2017-02-20 17:00:35 +00:00
py-trytond Switch py-dateutils to plain DEPENDS. 2017-02-20 17:00:35 +00:00
py-txaio 2.8.0: 2017-06-21 18:39:58 +00:00
py-typing Changes: sync with Python 3.6.1 2017-05-10 16:50:20 +00:00
py-unit Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-unitgui Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-unittest2
py-unittest2py3k Use "${MV} || ${TRUE}" and "${RM} -f" consistently in post-install targets. 2017-01-03 13:23:01 +00:00
py-urwid
py-usb Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-uuid Extend SHA512 checksums to various files I have on my local distfile 2017-03-23 17:06:45 +00:00
py-uvloop Added 'python' to CATEGORIES 2017-06-24 07:13:05 +00:00
py-vcversioner
py-vine Added devel/py-vine version 1.1.3 2017-04-09 17:04:28 +00:00
py-virtualenv Use "${MV} || ${TRUE}" and "${RM} -f" consistently in post-install targets. 2017-01-03 13:23:01 +00:00
py-wcwidth
py-wheel Changes 0.29.0: 2017-04-08 07:27:33 +00:00
py-whichcraft
py-windbg Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-wrapt Fix build with Perl 5.26.0 2017-06-07 14:42:23 +00:00
py-xdg
py-zanata-python-client Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-zconfig Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
py-ZopeComponent Update devel/py-ZopeComponent to 4.3.0. 2016-11-11 09:45:13 +00:00
py-ZopeConfiguration Import zope.configuration 4.0.3 as devel/py-ZopeConfiguration. 2017-04-25 17:48:12 +00:00
py-ZopeEvent
py-ZopeI18NMessageid Import zope.i18nmessageid 4.0.3 as devel/py-ZopeI18NMessageid. 2017-04-25 17:28:13 +00:00
py-ZopeInterface Updated py-ZopeInterface to 4.4.2. 2017-06-19 20:50:27 +00:00
py-ZopeSchema Import zope.schema 4.4.2 as devel/py-ZopeSchema. 2017-04-25 17:23:28 +00:00
python-mode
pythontidy
qbzr Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
qconf Revbump after icu update 2017-04-22 21:03:07 +00:00
qjson
qof Update doxygen-depend version to 1.8.12 (or add new BUILD_DEPENDS+) 2016-11-24 14:11:31 +00:00
qore-uuid-module
qtscriptgenerator
quilt
R-evaluate Update to 0.10 2016-12-18 02:28:50 +00:00
R-magrittr
R-proto Update to 1.0.0 2016-12-17 07:33:08 +00:00
R-Rcpp Update to 0.12.8 2016-12-17 07:28:05 +00:00
radamsa Import radamsa-0.5 as devel/radamsa. 2017-02-11 02:08:16 +00:00
radare2 Recursive bump for libzip shlib major bump. 2017-02-23 07:44:09 +00:00
radare2-valabind Recursive bump for lang/vala 2017-05-29 12:20:23 +00:00
ragel Updated ragel to 6.10. 2017-04-19 18:32:47 +00:00
rainbow-delimiters-el
rapidsvn Revbump after icu update 2017-04-22 21:03:07 +00:00
ratfor
RBTools Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
rcs
rdp - Correction to HOMEPAGE 2017-01-29 06:48:27 +00:00
re2 Update devel/re2 to 2017-03-01. No changelog released. 2017-03-31 17:19:23 +00:00
re2c Updated devel/re2c to 0.16 2017-01-02 08:09:45 +00:00
readline Remove unneeded dragonfly workaround. 2016-12-30 11:45:51 +00:00
rebar
refinecvs
Renaissance Revbump after icu update 2017-04-22 21:03:07 +00:00
reposurgeon Updated devel/reposurgeon to 3.41 2017-02-11 00:29:37 +00:00
ropper Updated devel/ropper 1.9.5 to 1.10.10 2017-02-11 01:35:27 +00:00
roundup Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
rox-lib Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
rpc2
rscode
rsltc
rt-mysql pkgrevision bump for changed apache default. 2017-03-12 07:20:51 +00:00
rt-pgsql pkgrevision bump for changed apache default. 2017-03-12 07:20:51 +00:00
rt3 Recursive revbump from lang/perl5 5.26.0 2017-06-05 14:23:47 +00:00
rt4 Add missing runtime dependency in p5-JSON-MaybeXS 2017-05-21 06:45:38 +00:00
RTFM
RTx-RightsMatrix
rubigen Bump revision due to change of PKGPATH of depending rails components' packages. 2017-06-21 15:42:10 +00:00
ruby-abstract
ruby-activejob42 Switch most of Ruby on Rails related packages to updated frame work. 2017-06-21 13:12:20 +00:00
ruby-activemodel32 Switch most of Ruby on Rails related packages to updated frame work. 2017-06-21 13:12:20 +00:00
ruby-activemodel42 Switch most of Ruby on Rails related packages to updated frame work. 2017-06-21 13:12:20 +00:00
ruby-activesupport32 Switch most of Ruby on Rails related packages to updated frame work. 2017-06-21 13:12:20 +00:00
ruby-activesupport42 Switch most of Ruby on Rails related packages to updated frame work. 2017-06-21 13:12:20 +00:00
ruby-algorithms
ruby-amstd
ruby-assistance
ruby-atomic
ruby-backports
ruby-bit-struct Update ruby-bit-struct to 0.16. 2017-06-04 15:46:52 +00:00
ruby-blankslate
ruby-bsearch
ruby-byaccr
ruby-celluloid
ruby-celluloid-essentials
ruby-celluloid-extras
ruby-celluloid-fsm
ruby-celluloid-pool
ruby-celluloid-supervision
ruby-cmd
ruby-contracts Update ruby-contracts to 0.16.0. 2017-06-04 15:48:06 +00:00
ruby-cucumber-core Import ruby-cucumber-core-2.0.0 as devel/ruby-cucumber-core 2017-02-13 03:22:02 +00:00
ruby-cucumber-wire Import ruby-cucumber-wire-0.0.1 as devel/ruby-cucumber-wire 2017-02-20 05:52:31 +00:00
ruby-curses Now, move ruby-curses-gem to ruby-curses overriding part of ruby18 version. 2017-04-22 18:20:14 +00:00
ruby-daemon_controller
ruby-delayer
ruby-delayer-deferred Update ruby-delayer-deferred to 2.0.0. 2017-06-10 07:55:56 +00:00
ruby-dep Add 24 to RUBY_VERSIONS_ACCEPTED. 2017-06-18 13:48:53 +00:00
ruby-deprecated
ruby-dhaka
ruby-docile
ruby-eet * Drop task for release from Rakefile which depends on files in prior 2017-06-05 16:06:57 +00:00
ruby-eventmachine Update ruby-eventmachine to 1.2.3. 2017-03-12 14:34:01 +00:00
ruby-extlib
ruby-facade
ruby-fast_gettext Update ruby-fast_gettext to 1.4.1. 2017-06-21 13:56:17 +00:00
ruby-ffi Update ruby-ffi to 1.9.18. 2017-03-13 16:18:34 +00:00
ruby-ffi-yajl
ruby-fiddle * Replace RUBY_VERSION_FULL with RUBY_VERSION since there is no 2017-05-30 15:47:16 +00:00
ruby-flexmock Update ruby-flexmock to 2.3.5. 2017-03-13 16:24:36 +00:00
ruby-forwardable-extended
ruby-gemcutter
ruby-getopt
ruby-gettext
ruby-gettext-activerecord Bump revision due to change of PKGPATH of depending rails components' packages. 2017-06-21 15:42:10 +00:00
ruby-gettext-rails Bump revision due to change of PKGPATH of depending rails components' packages. 2017-06-21 15:42:10 +00:00
ruby-gettext-setup Add ruby-gettext-setup package version 0.25. 2017-06-10 16:02:10 +00:00
ruby-gettext_i18n_rails
ruby-globalid Bump revision due to change of PKGPATH of depending rails components' packages. 2017-06-21 15:42:10 +00:00
ruby-gnome2-atk Move MAINTAINER line to each gem package. 2017-06-11 05:51:39 +00:00
ruby-gnome2-gio Move MAINTAINER line to each gem package. 2017-06-11 05:51:39 +00:00
ruby-gnome2-glib Move MAINTAINER line to each gem package. 2017-06-11 05:51:39 +00:00
ruby-gnome2-gobject-introspection Move MAINTAINER line to each gem package. 2017-06-11 05:51:39 +00:00
ruby-gnome2-pango Move MAINTAINER line to each gem package. 2017-06-11 05:51:39 +00:00
ruby-hashery
ruby-heckle
ruby-highline
ruby-hike
ruby-i18n Update ruby-i18n to 0.8.4. 2017-06-04 15:52:15 +00:00
ruby-iniparse Add ruby-iniparse package version 1.4.3. 2017-06-04 15:54:12 +00:00
ruby-inline
ruby-instance_storage
ruby-io-like
ruby-kgio Update ruby-kgio to 2.11.0. 2017-03-12 14:38:17 +00:00
ruby-lazy_priority_queue
ruby-libyajl2
ruby-little-plugger
ruby-locale
ruby-locale-rails
ruby-lockfile
ruby-log4r
ruby-logging Update ruby-logging to 2.2.2. 2017-04-22 16:22:56 +00:00
ruby-loquacious
ruby-memcache
ruby-memoist
ruby-mercenary
ruby-metaclass
ruby-metaid
ruby-minitest Update ruby-minitest to 5.10.2. 2017-06-04 15:55:56 +00:00
ruby-mixlib-authentication Update ruby-mixlib-authentication to 1.4.1. 2017-06-11 14:47:38 +00:00
ruby-mixlib-cli Update ruby-mixlib-cli to 1.7.0. 2017-06-11 14:53:03 +00:00
ruby-mixlib-config Update ruby-mixlib-config to 2.2.4. 2017-06-11 14:56:56 +00:00
ruby-mixlib-log Update ruby-mixlib-log to 1.7.1. 2017-06-11 15:01:14 +00:00
ruby-mixlib-shellout UPdate ruby-mixlib-shellout to 2.2.7. 2017-06-11 15:21:35 +00:00
ruby-mkrf
ruby-mocha
ruby-mode Update ruby-mode to 2.4.1. 2017-06-18 14:08:25 +00:00
ruby-msgpack Update ruby-msgpack to 1.1.0. 2017-03-12 14:40:53 +00:00
ruby-multi_test Import ruby-multi_test-0.1.2 as devel/ruby-multi_test 2017-02-21 06:30:46 +00:00
ruby-native-package-installer Update ruby-native-package-installer to 1.0.4. 2017-06-05 14:10:53 +00:00
ruby-ncurses
ruby-needle
ruby-nenv
ruby-octokit Update ruby-octokit to 4.7.0. 2017-04-22 16:24:44 +00:00
ruby-ole Update ruby-ole to 1.2.12.1. 2017-03-19 16:44:55 +00:00
ruby-open4
ruby-parseconfig
ruby-parser Update ruby-parser to 3.9.0. 2017-04-22 16:25:55 +00:00
ruby-parsetree
ruby-parslet Update ruby-parslet to 1.8.0. 2017-04-22 16:27:32 +00:00
ruby-path
ruby-pathname2
ruby-pathutil
ruby-pkg-config Update ruby-pkg-config to 1.2.3. 2017-06-04 15:56:52 +00:00
ruby-polyglot
ruby-posix-spawn Update ruby-posix-spawn to 0.3.13. 2017-03-19 17:05:56 +00:00
ruby-power_assert Update ruby-power_assert to 1.0.2. 2017-06-04 16:06:01 +00:00
ruby-priority-queue
ruby-racc
ruby-railties32 Fix test conditional in pre-configure rule. 2017-06-21 14:42:55 +00:00
ruby-railties42 Fix test conditional in pre-configure rule. 2017-06-21 14:42:55 +00:00
ruby-randexp
ruby-rb-fsevent Update rb-fsevent to 0.9.8. 2017-03-19 16:34:30 +00:00
ruby-rb-kqueue Update ruby-rb-kqueue to 0.2.5. 2017-06-04 16:11:29 +00:00
ruby-rbtree Relax patten in GEM_CLEANBUILD. 2017-06-02 04:16:35 +00:00
ruby-rcsparse
ruby-rd-mode
ruby-readline Replace RUBY_VERSION_FULL with RUBY_VERSION since there is no 2017-05-30 15:46:21 +00:00
ruby-redmine Set RUBY_VERSIONS_ACCEPTED to 22 instead of using 2017-06-21 02:13:14 +00:00
ruby-redmine-flatly-light-theme Make Redmine great again too. General cleanup as well as updating all the 2017-01-04 23:05:11 +00:00
ruby-redmine-gitmike-theme Make Redmine great again too. General cleanup as well as updating all the 2017-01-04 23:05:13 +00:00
ruby-redmine-minimalflat-theme Make Redmine great again too. General cleanup as well as updating all the 2017-01-04 23:05:13 +00:00
ruby-redmine-red-andy-theme
ruby-redmine_bootstrap_kit Make Redmine great again too. General cleanup as well as updating all the 2017-01-04 23:05:11 +00:00
ruby-redmine_code_review Make Redmine great again too. General cleanup as well as updating all the 2017-01-04 23:05:11 +00:00
ruby-redmine_jenkins
ruby-redmine_lightbox2 Update to version 0.3.2, which fixes an issue with how thumbnails are 2017-02-02 00:27:24 +00:00
ruby-redmine_startpage
ruby-redmine_theme_changer
ruby-redmine_work_time Make Redmine great again too. General cleanup as well as updating all the 2017-01-04 23:05:13 +00:00
ruby-ref
ruby-rgl Update ruby-rgl to 0.5.3. 2017-06-04 16:13:07 +00:00
ruby-rspec Update ruby-rspec to 3.6.0. 2017-06-05 14:07:47 +00:00
ruby-rspec-core Update ruby-rspec-core to 3.6.0. 2017-06-05 14:05:15 +00:00
ruby-rspec-expectations Update ruby-rspec-expectations to 3.6.0. 2017-06-05 14:05:45 +00:00
ruby-rspec-its Add ruby-rspec-its package version 1.2.0. 2017-06-10 16:21:53 +00:00
ruby-rspec-logsplit
ruby-rspec-mocks Update ruby-rspec-mocks to 3.6.0. 2017-06-05 14:06:11 +00:00
ruby-rspec-rails Bump revision due to change of PKGPATH of depending rails components' packages. 2017-06-21 15:42:10 +00:00
ruby-rspec-support Update ruby-rspec-support to 3.6.0. 2017-06-05 14:04:42 +00:00
ruby-rspec_junit_formatter Add ruby-rspec_junit_formatter package version 0.2.3. 2017-06-10 16:25:11 +00:00
ruby-rugged Update ruby-rugged to 0.25.1.1. 2017-02-18 13:18:17 +00:00
ruby-SDL
ruby-setup
ruby-sexp-processor Update ruby-sexp-processor to 4.9.0. 2017-04-22 16:30:43 +00:00
ruby-shoulda-context Update ruby-shoulda-context to 1.2.2. 2017-06-12 15:44:27 +00:00
ruby-shoulda-matchers Bump revision due to change of PKGPATH of depending rails components' packages. 2017-06-21 15:42:10 +00:00
ruby-simple_uuid Reset MAINTAINER after tonnerre resigned. 2017-04-19 11:24:36 +00:00
ruby-simplecov Update ruby-simplecov to 0.14.1. 2017-03-20 12:32:45 +00:00
ruby-simplecov-html Update ruby-simplecov-html to 0.10.1. 2017-06-05 14:15:59 +00:00
ruby-spruz
ruby-stomp Update ruby-stomp to 1.4.4. 2017-06-12 15:50:11 +00:00
ruby-stream
ruby-subexec
ruby-subversion Revbump after icu update 2017-04-22 21:03:07 +00:00
ruby-templater
ruby-term-ansicolor Update ruby-term-ansicolor to 1.6.0. 2017-04-22 16:32:13 +00:00
ruby-termcolor
ruby-test-spec
ruby-test-unit Remove ruby21 reference. 2017-06-20 13:42:32 +00:00
ruby-test-unit-notify Remove ruby21 reference. 2017-06-20 13:42:32 +00:00
ruby-thor Update ruby-thor to 0.19.4. 2017-03-20 12:48:32 +00:00
ruby-thrift Reset MAINTAINER after tonnerre resigned. 2017-04-19 11:24:36 +00:00
ruby-thrift_client Reset MAINTAINER after tonnerre resigned. 2017-04-19 11:24:36 +00:00
ruby-tins Update ruby-tinsto 1.14.0. 2017-06-05 14:23:21 +00:00
ruby-turn
ruby-uglifier
ruby-uuidtools
ruby-validatable
ruby-wmi-lite
ruby-zookeeper
ruby2ruby Update ruby2ruby to 2.3.2. 2017-03-12 14:31:24 +00:00
rudiments Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
rvm
rx
sablecc
scintilla Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
scmcvs scmcvs: try to find __fpending in stdio.h, too 2017-05-12 05:13:43 +00:00
scons Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
sdcc
sdcc3 Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
SDL Recursive revbump from audio/pulseaudio-10.0 2017-01-21 20:06:44 +00:00
SDL-intro-en
SDL-intro-ko
SDL2 For bsd audio backend, use correct prinfo for play and record. 2017-01-26 03:46:20 +00:00
SDL_gfx
SDL_Pango Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
SDL_ttf
SDLmm
semantic
semi
sfio
sfslite
sgb
sgi-stl
sgi-stl-docs
shtk Update shtk to 1.7: 2017-02-17 21:20:07 +00:00
shunit2 Import shunit2-2.1.6 as devel/shunit2. 2017-07-04 10:06:56 +00:00
silc-toolkit Convert all occurrences (353 by my count) of 2017-01-19 18:52:01 +00:00
slib
slibtool Update slibtool to 0.5.13 2017-06-10 22:02:36 +00:00
sml-mode
snappy snappy now requires googletest to build, so include the buildlink3.mk file 2017-06-24 18:57:28 +00:00
snappy-java10
sofia-sip
SOPE Revbump after icu update 2017-04-22 21:03:07 +00:00
sparse
sparsehash
spiff
spin
splint splint: use the standard check for C99 before including a C99 header 2017-05-05 07:34:06 +00:00
st
startbug1 Revbump after icu update 2017-04-22 21:03:07 +00:00
stfl
stgit Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
stooop
subversion Update Subversion to 1.9.5. 2016-11-29 20:12:41 +00:00
subversion-base Revbump after icu update 2017-04-22 21:03:07 +00:00
sunifdef
svk These packages all require the PERL_USE_UNSAFE_INC hack. 2017-06-28 08:27:40 +00:00
svn-bisect Add explicit dependency on p5-IO-All. Bump revision. 2017-06-30 17:57:41 +00:00
swig Add examples to CHECK_WRKREF_SKIP. 2017-05-04 12:21:45 +00:00
swig2 Add examples to CHECK_WRKREF_SKIP. 2017-05-04 12:21:45 +00:00
swig3 SWIG-3.0.12 summary: 2017-04-01 05:18:19 +00:00
swt Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
syncdir
sysexits
tailor Add python-3.6 to incompatible versions. 2017-01-01 14:43:22 +00:00
talloc Updated talloc to 2.1.9. 2017-03-05 14:43:08 +00:00
tavrasm
tcl-tclcl
tclap
tcllib
tclreadline
teem
tet3
tex-etoolbox Update to TeXlive 2017 2017-06-21 06:13:14 +00:00
tex-etoolbox-doc Update to TeXlive 2017 2017-06-21 06:13:14 +00:00
tex-l3experimental Update to TeXlive 2017 2017-06-21 08:28:41 +00:00
tex-l3kernel Update to TeXlive 2017 2017-06-21 08:28:41 +00:00
tex-l3kernel-doc Update to TeXlive 2017 2017-06-21 08:28:41 +00:00
tex-l3packages Update to TeXlive 2017 2017-06-21 08:28:41 +00:00
tex-l3packages-doc Add a missing entry to tex-l3packages-doc's PLIST 2017-06-27 21:35:27 +00:00
tex-latexbug Add tex-latexbug{,-doc} 1.0a 2017-06-23 23:18:50 +00:00
tex-latexbug-doc Add tex-latexbug{,-doc} 1.0a 2017-06-23 23:18:50 +00:00
tex-lualibs Update to TeXlive 2017 2017-06-21 08:28:41 +00:00
tex-lualibs-doc Update to TeXlive 2017 2017-06-21 08:28:41 +00:00
tex-luatexbase
tex-luatexbase-doc
tex-multido
tex-multido-doc
tex-pst-uml
tex-pst-uml-doc
tex-xifthen
tex-xifthen-doc
threadweaver Revbump after icu update 2017-04-22 21:03:07 +00:00
tig Use the curses framework. 2017-01-04 18:06:59 +00:00
tinycthread
tkcvs
tkdiff
tla
tlsh Fix pointer abuse. 2016-12-17 14:18:32 +00:00
tmake
tmin
topgit
tpasm
tradcpp try again, this time with the patch 2016-12-16 18:30:58 +00:00
transifex-client Fixed definition of WRKSRC to also work when PKGREVISION is set. 2017-01-29 14:57:42 +00:00
tre
treecc
trio
tvision
ucl
ucommon Fix access to protected members. 2016-12-19 13:33:43 +00:00
ucpp
umbrello Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
undebt
unidiff
uno
userspace-rcu
uthash
valgrind adjust PLIST for last update 2016-12-05 20:17:56 +00:00
vanessa_adt
vanessa_logger
vanessa_socket
vera++ Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
visualvm Extend SHA512 checksums to various files I have on my local distfile 2017-03-23 17:06:45 +00:00
vtcl
waf Updated waf to 1.9.12. 2017-06-14 12:15:43 +00:00
wide
woboq_codebrowser Convert CXXFLAGS setting C++ standard to USE_LANGUAGES. 2017-05-03 08:38:38 +00:00
xa65
xdelta
xdelta3
xfce4-conf Downgrade xfce4-conf to 4.12.1 to make the panel working again. 2017-06-20 16:11:05 +00:00
xfce4-dev-tools Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
xmake
xorg-util-macros Updated xorg-util-macros to 1.19.1. 2017-02-02 18:42:55 +00:00
xsd Recursive revbump from boost update 2017-04-30 01:21:19 +00:00
xulrunner10 Revbump after icu update 2017-04-22 21:03:07 +00:00
xulrunner17 Revbump after icu update 2017-04-22 21:03:07 +00:00
xulrunner24 Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
xulrunner31 Revbump after icu update 2017-04-22 21:03:07 +00:00
xulrunner38 Recursive revbump from fonts/harfbuzz 2017-02-12 06:24:36 +00:00
xulrunner45 Update to 45.9.0 2017-05-11 14:45:32 +00:00
xulrunner192 Revbump after icu update 2017-04-22 21:03:07 +00:00
xxgdb
yajl
yasm
z80-asm
ZenTest
zlib Changes in 1.2.11 (15 Jan 2017) 2017-04-04 08:57:33 +00:00
zookeeper
zzuf Update zzuf to version 0.15 2017-04-16 21:46:12 +00:00
Makefile Add shunit2. 2017-07-04 10:07:43 +00:00