[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: d2443903643b8662ee5ac0bd03d3bbad964a9633
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:55:37 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:47 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=d2443903

Revert "SpawnProcess: add _main coroutine"

This reverts commit 8074127bbc213fde75d51309c8fb4ee33ad278aa.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/SpawnProcess.py | 33 +++--
 1 file changed, 11 insertions(+), 22 deletions(-)

diff --git a/lib/_emerge/SpawnProcess.py b/lib/_emerge/SpawnProcess.py
index cda615ded..ba58d9d0e 100644
--- a/lib/_emerge/SpawnProcess.py
+++ b/lib/_emerge/SpawnProcess.py
@@ -20,7 +20,6 @@ from portage.localization import _
 from portage.output import EOutput
 from portage.util import writemsg_level
 from portage.util._async.PipeLogger import PipeLogger
-from portage.util.futures import asyncio
 from portage.util.futures.compat_coroutine import coroutine
 
 class SpawnProcess(SubProcess):
@@ -37,7 +36,7 @@ class SpawnProcess(SubProcess):
"unshare_ipc", "unshare_mount", "unshare_pid", "unshare_net")
 
__slots__ = ("args",) + \
-   _spawn_kwarg_names + ("_main_task", "_selinux_type",)
+   _spawn_kwarg_names + ("_pipe_logger", "_selinux_type",)
 
# Max number of attempts to kill the processes listed in cgroup.procs,
# given that processes may fork before they can be killed.
@@ -142,28 +141,13 @@ class SpawnProcess(SubProcess):
fcntl.fcntl(stdout_fd,
fcntl.F_GETFD) | 
fcntl.FD_CLOEXEC)
 
-   pipe_logger = PipeLogger(background=self.background,
+   self._pipe_logger = PipeLogger(background=self.background,
scheduler=self.scheduler, input_fd=master_fd,
log_file_path=log_file_path,
stdout_fd=stdout_fd)
+   self._pipe_logger.addExitListener(self._pipe_logger_exit)
self._registered = True
-   yield pipe_logger.async_start()
-
-   self._main_task = asyncio.ensure_future(
-   self._main(pipe_logger), loop=self.scheduler)
-   self._main_task.add_done_callback(self._main_exit)
-
-   @coroutine
-   def _main(self, pipe_logger):
-   if pipe_logger.poll() is None:
-   yield pipe_logger.async_wait()
-
-   def _main_exit(self, main_task):
-   try:
-   main_task.result()
-   except asyncio.CancelledError:
-   self.cancel()
-   self._async_waitpid()
+   yield self._pipe_logger.async_start()
 
def _can_log(self, slave_fd):
return True
@@ -187,16 +171,21 @@ class SpawnProcess(SubProcess):
 
return spawn_func(args, **kwargs)
 
+   def _pipe_logger_exit(self, pipe_logger):
+   self._pipe_logger = None
+   self._async_waitpid()
+
def _unregister(self):
SubProcess._unregister(self)
if self.cgroup is not None:
self._cgroup_cleanup()
self.cgroup = None
+   if self._pipe_logger is not None:
+   self._pipe_logger.cancel()
+   self._pipe_logger = None
 
def _cancel(self):
SubProcess._cancel(self)
-   if self._main_task is not None:
-   self._main_task.cancel()
self._cgroup_cleanup()
 
def _cgroup_cleanup(self):



[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: acd8f3a3841f3be50d4d649bb7180e3e0c77acfc
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:03:56 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:49 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=acd8f3a3

Revert "AsynchronousTask: Call _start_hook after _start_async"

This reverts commit 036c644712c36b2d67e818e6f60aa753ebd6acaf.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/AsynchronousTask.py | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)

diff --git a/lib/_emerge/AsynchronousTask.py b/lib/_emerge/AsynchronousTask.py
index 962c68547..b25a146c7 100644
--- a/lib/_emerge/AsynchronousTask.py
+++ b/lib/_emerge/AsynchronousTask.py
@@ -25,8 +25,8 @@ class AsynchronousTask(SlotObject):
 
@coroutine
def async_start(self):
-   yield self._async_start()
self._start_hook()
+   yield self._async_start()
 
@coroutine
def _async_start(self):
@@ -38,8 +38,8 @@ class AsynchronousTask(SlotObject):
"""
Start an asynchronous task and then return as soon as possible.
"""
-   self._start()
self._start_hook()
+   self._start()
 
def _start(self):
self.returncode = os.EX_OK



[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: f7e36d1e9d468b5a7f502e477ba1971f8334a5d9
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:53:39 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:47 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=f7e36d1e

Revert "SpawnProcess: cancel pipe_logger after async_start CancelledError"

This reverts commit d331f03ab25422e9afc2e752ea8e39c93a4b0bec.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/SpawnProcess.py | 7 +--
 1 file changed, 1 insertion(+), 6 deletions(-)

diff --git a/lib/_emerge/SpawnProcess.py b/lib/_emerge/SpawnProcess.py
index ab7971ca8..941b56683 100644
--- a/lib/_emerge/SpawnProcess.py
+++ b/lib/_emerge/SpawnProcess.py
@@ -147,12 +147,7 @@ class SpawnProcess(SubProcess):
log_file_path=log_file_path,
stdout_fd=stdout_fd)
self._registered = True
-   try:
-   yield pipe_logger.async_start()
-   except asyncio.CancelledError:
-   if pipe_logger.poll() is None:
-   pipe_logger.cancel()
-   raise
+   yield pipe_logger.async_start()
 
self._main_task = asyncio.ensure_future(
self._main(pipe_logger), loop=self.scheduler)



[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: a0700108913e85b359ea7c579147f8f1d7825b9e
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:07:25 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:49 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=a0700108

Revert "EbuildPhase: add _async_start coroutine"

This reverts commit c7e52d0466211907d20cdbc04f1e90e7da626694.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/EbuildPhase.py | 21 ++---
 lib/_emerge/SequentialTaskQueue.py | 14 +++---
 2 files changed, 13 insertions(+), 22 deletions(-)

diff --git a/lib/_emerge/EbuildPhase.py b/lib/_emerge/EbuildPhase.py
index f6b380e05..477e0ba97 100644
--- a/lib/_emerge/EbuildPhase.py
+++ b/lib/_emerge/EbuildPhase.py
@@ -23,7 +23,7 @@ from portage.util._dyn_libs.soname_deps_qa import (
 )
 from portage.package.ebuild.prepare_build_dirs import (_prepare_workdir,
_prepare_fake_distdir, _prepare_fake_filesdir)
-from portage.util.futures.compat_coroutine import coroutine, coroutine_return
+from portage.util.futures.compat_coroutine import coroutine
 from portage.util import writemsg
 from portage.util._async.AsyncTaskFuture import AsyncTaskFuture
 from portage.util.futures.executor.fork import ForkExecutor
@@ -69,10 +69,6 @@ class EbuildPhase(CompositeTask):
_locked_phases = ("setup", "preinst", "postinst", "prerm", "postrm")
 
def _start(self):
-   self.scheduler.run_until_complete(self._async_start())
-
-   @coroutine
-   def _async_start(self):
 
need_builddir = self.phase not in 
EbuildProcess._phases_without_builddir
 
@@ -142,17 +138,20 @@ class EbuildPhase(CompositeTask):
env_extractor = 
BinpkgEnvExtractor(background=self.background,
scheduler=self.scheduler, 
settings=self.settings)
if env_extractor.saved_env_exists():
-   self._current_task = env_extractor
-   yield env_extractor.async_start()
-   yield env_extractor.async_wait()
-   if self._default_exit(env_extractor) != 
os.EX_OK:
-   self._async_wait()
-   coroutine_return()
+   self._start_task(env_extractor, 
self._env_extractor_exit)
+   return
# If the environment.bz2 doesn't exist, then ebuild.sh 
will
# source the ebuild as a fallback.
 
self._start_lock()
 
+   def _env_extractor_exit(self, env_extractor):
+   if self._default_exit(env_extractor) != os.EX_OK:
+   self.wait()
+   return
+
+   self._start_lock()
+
def _start_lock(self):
if (self.phase in self._locked_phases and
"ebuild-locks" in self.settings.features):

diff --git a/lib/_emerge/SequentialTaskQueue.py 
b/lib/_emerge/SequentialTaskQueue.py
index 38ebb98d8..656e5cf7c 100644
--- a/lib/_emerge/SequentialTaskQueue.py
+++ b/lib/_emerge/SequentialTaskQueue.py
@@ -1,11 +1,9 @@
-# Copyright 1999-2020 Gentoo Authors
+# Copyright 1999-2012 Gentoo Foundation
 # Distributed under the terms of the GNU General Public License v2
 
 from collections import deque
 import sys
 
-from portage.util.futures import asyncio
-from portage.util.futures.compat_coroutine import coroutine
 from portage.util.SlotObject import SlotObject
 
 class SequentialTaskQueue(SlotObject):
@@ -43,23 +41,17 @@ class SequentialTaskQueue(SlotObject):
cancelled = getattr(task, "cancelled", None)
if not cancelled:
self.running_tasks.add(task)
-   future = 
asyncio.ensure_future(self._task_coroutine(task), loop=task.scheduler)
-   future.add_done_callback(lambda future: 
future.cancelled() or future.result())
# This callback will be invoked as soon 
as the task
# exits (before the future's done 
callback is called),
# and this is required in order for 
bool(self) to have
# an updated value for 
Scheduler._schedule to base
# assumptions upon. Delayed updates to 
bool(self) is
-   # what caused Scheduler to hang as in 
bug 709746.
+   # what caused Scheduler to hang as in 
bug 711322.
task.addExitListener(self._task_exit)
+   task.start()

[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: 971124a4cf7b0a578b7c8b87134743f8135481b6
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:55:13 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:47 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=971124a4

Revert "SpawnProcess: only cancel self._main_task if it's not done"

This reverts commit 10cc6febb701cde8f7c099f5ecdf177486e94b3c.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/SpawnProcess.py | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/lib/_emerge/SpawnProcess.py b/lib/_emerge/SpawnProcess.py
index aef000e22..cda615ded 100644
--- a/lib/_emerge/SpawnProcess.py
+++ b/lib/_emerge/SpawnProcess.py
@@ -196,7 +196,7 @@ class SpawnProcess(SubProcess):
def _cancel(self):
SubProcess._cancel(self)
if self._main_task is not None:
-   self._main_task.done() or self._main_task.cancel()
+   self._main_task.cancel()
self._cgroup_cleanup()
 
def _cgroup_cleanup(self):



[gentoo-commits] proj/portage:master commit in: lib/portage/tests/util/futures/, lib/portage/util/futures/, ...

2020-04-07 Thread Zac Medico
commit: bf1505777847aface5b4cac16b955071c2915ddd
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:03:34 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:48 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=bf150577

Revert "AsyncScheduler: use async_start method"

This reverts commit 8f47d3fe1190d4476ae9eebfafcebdfb1794fc05.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/portage/tests/ebuild/test_doebuild_fd_pipes.py |  8 +++--
 .../tests/util/futures/test_iter_completed.py  |  2 --
 lib/portage/util/_async/AsyncScheduler.py  | 20 ++--
 lib/portage/util/futures/iter_completed.py | 38 +-
 4 files changed, 15 insertions(+), 53 deletions(-)

diff --git a/lib/portage/tests/ebuild/test_doebuild_fd_pipes.py 
b/lib/portage/tests/ebuild/test_doebuild_fd_pipes.py
index 50fc5fe1c..05ea24c4b 100644
--- a/lib/portage/tests/ebuild/test_doebuild_fd_pipes.py
+++ b/lib/portage/tests/ebuild/test_doebuild_fd_pipes.py
@@ -109,16 +109,18 @@ class DoebuildFdPipesTestCase(TestCase):
output_fd: pw,
},
"prev_mtimes": {}})
-   producer.addStartListener(lambda producer: 
os.close(pw))
 
-   # PipeReader closes pr
consumer = PipeReader(
input_files={"producer" : pr})
 
task_scheduler = TaskScheduler(iter([producer, 
consumer]),
max_jobs=2)
 
-   
loop.run_until_complete(task_scheduler.async_start())
+   try:
+   
loop.run_until_complete(task_scheduler.async_start())
+   finally:
+   # PipeReader closes pr
+   os.close(pw)
 
task_scheduler.wait()
output = portage._unicode_decode(

diff --git a/lib/portage/tests/util/futures/test_iter_completed.py 
b/lib/portage/tests/util/futures/test_iter_completed.py
index 03ace915a..aa24f5685 100644
--- a/lib/portage/tests/util/futures/test_iter_completed.py
+++ b/lib/portage/tests/util/futures/test_iter_completed.py
@@ -76,8 +76,6 @@ class IterCompletedTestCase(TestCase):
 
for future_done_set in async_iter_completed(future_generator(),
max_jobs=True, max_load=True, loop=loop):
-   while not input_futures:
-   loop.run_until_complete(asyncio.sleep(0, 
loop=loop))
future_done_set.cancel()
break
 

diff --git a/lib/portage/util/_async/AsyncScheduler.py 
b/lib/portage/util/_async/AsyncScheduler.py
index b9070061a..c6b523eaa 100644
--- a/lib/portage/util/_async/AsyncScheduler.py
+++ b/lib/portage/util/_async/AsyncScheduler.py
@@ -1,11 +1,7 @@
 # Copyright 2012-2018 Gentoo Foundation
 # Distributed under the terms of the GNU General Public License v2
 
-import functools
-
 from portage import os
-from portage.util.futures import asyncio
-from portage.util.futures.compat_coroutine import coroutine
 from _emerge.AsynchronousTask import AsynchronousTask
 from _emerge.PollScheduler import PollScheduler
 
@@ -66,8 +62,8 @@ class AsyncScheduler(AsynchronousTask, PollScheduler):
else:
self._running_tasks.add(task)
task.scheduler = self._sched_iface
-   future = 
asyncio.ensure_future(self._task_coroutine(task), loop=self._sched_iface)
-   
future.add_done_callback(functools.partial(self._task_coroutine_done, task))
+   task.addExitListener(self._task_exit)
+   task.start()
 
if self._loadavg_check_id is not None:
self._loadavg_check_id.cancel()
@@ -77,18 +73,6 @@ class AsyncScheduler(AsynchronousTask, PollScheduler):
# Triggers cleanup and exit listeners if there's nothing left 
to do.
self.poll()
 
-   @coroutine
-   def _task_coroutine(self, task):
-   yield task.async_start()
-   yield task.async_wait()
-
-   def _task_coroutine_done(self, task, future):
-   try:
-   future.result()
-   except asyncio.CancelledError:
-   self.cancel()
-   self._task_exit(task)
-
def _task_exit(self, task):
self._running_tasks.discard(task)
if task.returncode != os.EX_OK:

diff --git 

[gentoo-commits] proj/portage:master commit in: lib/portage/tests/ebuild/, lib/portage/tests/lazyimport/, ...

2020-04-07 Thread Zac Medico
commit: 71ae5a58fe72bc32dce030210a73ea5c9eeb4a1c
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:13:17 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:49 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=71ae5a58

Revert "AsynchronousTask: add coroutine async_start method"

This reverts commit d66e9ec0b10522528d62e18b83e012c1ec121787.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/AsynchronousTask.py| 22 +-
 lib/_emerge/CompositeTask.py   | 17 +++--
 lib/_emerge/TaskSequence.py|  7 +--
 lib/portage/tests/ebuild/test_doebuild_fd_pipes.py |  6 ++
 lib/portage/tests/ebuild/test_doebuild_spawn.py|  6 +++---
 lib/portage/tests/ebuild/test_fetch.py |  9 +++--
 lib/portage/tests/ebuild/test_ipc_daemon.py|  4 ++--
 lib/portage/tests/ebuild/test_spawn.py |  4 ++--
 .../test_lazy_import_portage_baseline.py   |  6 +++---
 lib/portage/tests/locks/test_asynchronous_lock.py  | 18 +-
 lib/portage/tests/process/test_PopenProcess.py |  6 +++---
 .../tests/process/test_PopenProcessBlockingIO.py   |  4 ++--
 lib/portage/tests/process/test_poll.py |  4 ++--
 .../util/futures/test_done_callback_after_exit.py  |  2 +-
 .../tests/util/futures/test_iter_completed.py  | 16 +---
 lib/portage/tests/util/test_file_copier.py |  6 +++---
 16 files changed, 49 insertions(+), 88 deletions(-)

diff --git a/lib/_emerge/AsynchronousTask.py b/lib/_emerge/AsynchronousTask.py
index b25a146c7..28beb4992 100644
--- a/lib/_emerge/AsynchronousTask.py
+++ b/lib/_emerge/AsynchronousTask.py
@@ -1,11 +1,10 @@
-# Copyright 1999-2020 Gentoo Authors
+# Copyright 1999-2018 Gentoo Foundation
 # Distributed under the terms of the GNU General Public License v2
 
 import signal
 
 from portage import os
 from portage.util.futures import asyncio
-from portage.util.futures.compat_coroutine import coroutine, coroutine_return
 from portage.util.SlotObject import SlotObject
 
 class AsynchronousTask(SlotObject):
@@ -23,17 +22,6 @@ class AsynchronousTask(SlotObject):
 
_cancelled_returncode = - signal.SIGINT
 
-   @coroutine
-   def async_start(self):
-   self._start_hook()
-   yield self._async_start()
-
-   @coroutine
-   def _async_start(self):
-   self._start()
-   coroutine_return()
-   yield None
-
def start(self):
"""
Start an asynchronous task and then return as soon as possible.
@@ -41,10 +29,6 @@ class AsynchronousTask(SlotObject):
self._start_hook()
self._start()
 
-   def _start(self):
-   self.returncode = os.EX_OK
-   self._async_wait()
-
def async_wait(self):
"""
Wait for returncode asynchronously. Notification is available
@@ -65,6 +49,10 @@ class AsynchronousTask(SlotObject):
self._async_wait()
return waiter
 
+   def _start(self):
+   self.returncode = os.EX_OK
+   self._async_wait()
+
def isAlive(self):
return self.returncode is None
 

diff --git a/lib/_emerge/CompositeTask.py b/lib/_emerge/CompositeTask.py
index 21129758a..72da6fac1 100644
--- a/lib/_emerge/CompositeTask.py
+++ b/lib/_emerge/CompositeTask.py
@@ -1,10 +1,8 @@
-# Copyright 1999-2020 Gentoo Authors
+# Copyright 1999-2018 Gentoo Foundation
 # Distributed under the terms of the GNU General Public License v2
 
 from _emerge.AsynchronousTask import AsynchronousTask
 from portage import os
-from portage.util.futures import asyncio
-
 
 class CompositeTask(AsynchronousTask):
 
@@ -100,7 +98,7 @@ class CompositeTask(AsynchronousTask):
def _start_task(self, task, exit_handler):
"""
Register exit handler for the given task, set it
-   as self._current_task, and call task.async_start().
+   as self._current_task, and call task.start().
 
Subclasses can use this as a generic way to start
a task.
@@ -112,16 +110,7 @@ class CompositeTask(AsynchronousTask):
pass
task.addExitListener(exit_handler)
self._current_task = task
-   result = asyncio.ensure_future(task.async_start(), 
loop=self.scheduler)
-   result.add_done_callback(self._current_task_start_cb)
-
-   def _current_task_start_cb(self, future):
-   try:
-   future.result()
-   except asyncio.CancelledError:
-   self.cancelled = True
-   self._was_cancelled()
-   self._async_wait()
+   task.start()
 
def 

[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: 62ee9ec33821768388cf16a3a1e7b603c845f0c9
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:09:49 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:49 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=62ee9ec3

Revert "AbstractEbuildProcess: add _async_start coroutine"

This reverts commit a287c49f84ad3af7c8e20bebd116ea972f318e04.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/AbstractEbuildProcess.py | 33 -
 lib/_emerge/MiscFunctionsProcess.py  |  8 +++-
 2 files changed, 27 insertions(+), 14 deletions(-)

diff --git a/lib/_emerge/AbstractEbuildProcess.py 
b/lib/_emerge/AbstractEbuildProcess.py
index fd8a40cc1..1c1955cfe 100644
--- a/lib/_emerge/AbstractEbuildProcess.py
+++ b/lib/_emerge/AbstractEbuildProcess.py
@@ -1,4 +1,4 @@
-# Copyright 1999-2020 Gentoo Authors
+# Copyright 1999-2019 Gentoo Foundation
 # Distributed under the terms of the GNU General Public License v2
 
 import errno
@@ -19,7 +19,6 @@ from portage.package.ebuild._ipc.ExitCommand import 
ExitCommand
 from portage.package.ebuild._ipc.QueryCommand import QueryCommand
 from portage import shutil, os
 from portage.util.futures import asyncio
-from portage.util.futures.compat_coroutine import coroutine, coroutine_return
 from portage.util._pty import _create_pty_or_pipe
 from portage.util import apply_secpass_permissions
 
@@ -31,7 +30,7 @@ class AbstractEbuildProcess(SpawnProcess):
 
__slots__ = ('phase', 'settings',) + \
('_build_dir', '_build_dir_unlock', '_ipc_daemon',
-   '_exit_command', '_exit_timeout_id')
+   '_exit_command', '_exit_timeout_id', '_start_future')
 
_phases_without_builddir = ('clean', 'cleanrm', 'depend', 'help',)
_phases_interactive_whitelist = ('config',)
@@ -56,10 +55,6 @@ class AbstractEbuildProcess(SpawnProcess):
self.phase = phase
 
def _start(self):
-   self.scheduler.run_until_complete(self._async_start())
-
-   @coroutine
-   def _async_start(self):
 
need_builddir = self.phase not in self._phases_without_builddir
 
@@ -74,7 +69,7 @@ class AbstractEbuildProcess(SpawnProcess):
self._eerror(textwrap.wrap(msg, 72))
self.returncode = 1
self._async_wait()
-   coroutine_return()
+   return
 
# Check if the cgroup hierarchy is in place. If it's not, mount 
it.
if (os.geteuid() == 0 and platform.system() == 'Linux'
@@ -147,7 +142,11 @@ class AbstractEbuildProcess(SpawnProcess):
if 'PORTAGE_BUILDDIR_LOCKED' not in 
self.settings:
self._build_dir = EbuildBuildDir(
scheduler=self.scheduler, 
settings=self.settings)
-   yield self._build_dir.async_lock()
+   self._start_future = 
self._build_dir.async_lock()
+   self._start_future.add_done_callback(
+   
functools.partial(self._start_post_builddir_lock,
+   
start_ipc_daemon=start_ipc_daemon))
+   return
else:
self.settings.pop('PORTAGE_IPC_DAEMON', None)
else:
@@ -168,6 +167,22 @@ class AbstractEbuildProcess(SpawnProcess):
else:
self.settings.pop('PORTAGE_EBUILD_EXIT_FILE', 
None)
 
+   
self._start_post_builddir_lock(start_ipc_daemon=start_ipc_daemon)
+
+   def _start_post_builddir_lock(self, lock_future=None, 
start_ipc_daemon=False):
+   if lock_future is not None:
+   if lock_future is not self._start_future:
+   raise AssertionError('lock_future is not 
self._start_future')
+   self._start_future = None
+   if lock_future.cancelled():
+   self._build_dir = None
+   self.cancelled = True
+   self._was_cancelled()
+   self._async_wait()
+   return
+
+   lock_future.result()
+
if start_ipc_daemon:
self.settings['PORTAGE_IPC_DAEMON'] = "1"
self._start_ipc_daemon()

diff --git a/lib/_emerge/MiscFunctionsProcess.py 
b/lib/_emerge/MiscFunctionsProcess.py
index cb0363820..89fd22635 100644
--- a/lib/_emerge/MiscFunctionsProcess.py
+++ b/lib/_emerge/MiscFunctionsProcess.py
@@ -1,9 +1,8 @@
-# Copyright 1999-2020 Gentoo Authors
+# Copyright 

[gentoo-commits] proj/portage:master commit in: lib/_emerge/, lib/portage/util/futures/executor/

2020-04-07 Thread Zac Medico
commit: 174b624d6a2d863d9779b0c2c4035ff33ba46a90
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:01:31 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:48 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=174b624d

Revert "ForkExecutor: use async_start method"

This reverts commit 4df7a0a0c16c5ded65ad601d39840797b7704770.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/AsynchronousTask.py   | 15 ++-
 lib/portage/util/futures/executor/fork.py | 21 +++--
 2 files changed, 5 insertions(+), 31 deletions(-)

diff --git a/lib/_emerge/AsynchronousTask.py b/lib/_emerge/AsynchronousTask.py
index c4197d468..962c68547 100644
--- a/lib/_emerge/AsynchronousTask.py
+++ b/lib/_emerge/AsynchronousTask.py
@@ -25,19 +25,8 @@ class AsynchronousTask(SlotObject):
 
@coroutine
def async_start(self):
-   try:
-   if self._was_cancelled():
-   raise asyncio.CancelledError
-   yield self._async_start()
-   if self._was_cancelled():
-   raise asyncio.CancelledError
-   except asyncio.CancelledError:
-   self.cancel()
-   self._was_cancelled()
-   self._async_wait()
-   raise
-   finally:
-   self._start_hook()
+   yield self._async_start()
+   self._start_hook()
 
@coroutine
def _async_start(self):

diff --git a/lib/portage/util/futures/executor/fork.py 
b/lib/portage/util/futures/executor/fork.py
index 3549fdb31..add7b3c9e 100644
--- a/lib/portage/util/futures/executor/fork.py
+++ b/lib/portage/util/futures/executor/fork.py
@@ -13,7 +13,6 @@ import traceback
 
 from portage.util._async.AsyncFunction import AsyncFunction
 from portage.util.futures import asyncio
-from portage.util.futures.compat_coroutine import coroutine
 from portage.util.cpuinfo import get_cpu_count
 
 
@@ -52,25 +51,11 @@ class ForkExecutor(object):
while (not self._shutdown and self._submit_queue and
len(self._running_tasks) < self._max_workers):
future, proc = self._submit_queue.popleft()
+   
future.add_done_callback(functools.partial(self._cancel_cb, proc))
+   proc.addExitListener(functools.partial(self._proc_exit, 
future))
proc.scheduler = self._loop
+   proc.start()
self._running_tasks[id(proc)] = proc
-   
future.add_done_callback(functools.partial(self._cancel_cb, proc))
-   proc_future = 
asyncio.ensure_future(self._proc_coroutine(proc), loop=self._loop)
-   
proc_future.add_done_callback(functools.partial(self._proc_coroutine_done, 
future, proc))
-
-   @coroutine
-   def _proc_coroutine(self, proc):
-   yield proc.async_start()
-   yield proc.async_wait()
-
-   def _proc_coroutine_done(self, future, proc, proc_future):
-   try:
-   proc_future.result()
-   except asyncio.CancelledError:
-   future.done() or future.cancel()
-   if proc.poll() is None:
-   proc.cancel()
-   self._proc_exit(future, proc)
 
def _cancel_cb(self, proc, future):
if future.cancelled():



[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: 5f0f1daa25e4eef751660909610ab247aff50f39
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:02:13 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:48 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=5f0f1daa

Revert "EbuildBuildDir: use async_start method"

This reverts commit 2c596f49bab63c6c81dd4d68789823d45341264d.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/EbuildBuildDir.py | 122 +++---
 1 file changed, 78 insertions(+), 44 deletions(-)

diff --git a/lib/_emerge/EbuildBuildDir.py b/lib/_emerge/EbuildBuildDir.py
index 77dbff1fb..477113db8 100644
--- a/lib/_emerge/EbuildBuildDir.py
+++ b/lib/_emerge/EbuildBuildDir.py
@@ -1,12 +1,13 @@
-# Copyright 1999-2020 Gentoo Authors
+# Copyright 1999-2012 Gentoo Foundation
 # Distributed under the terms of the GNU General Public License v2
 
+import functools
+
 from _emerge.AsynchronousLock import AsynchronousLock
 
 import portage
 from portage import os
 from portage.exception import PortageException
-from portage.util.futures.compat_coroutine import coroutine
 from portage.util.SlotObject import SlotObject
 
 class EbuildBuildDir(SlotObject):
@@ -38,7 +39,6 @@ class EbuildBuildDir(SlotObject):
except OSError:
pass
 
-   @coroutine
def async_lock(self):
"""
Acquire the lock asynchronously. Notification is available
@@ -59,45 +59,60 @@ class EbuildBuildDir(SlotObject):
raise AssertionError('PORTAGE_BUILDDIR is unset')
catdir = os.path.dirname(dir_path)
self._catdir = catdir
-
-   try:
-   portage.util.ensure_dirs(os.path.dirname(catdir),
-   gid=portage.portage_gid,
-   mode=0o70, mask=0)
-   except PortageException:
-   if not os.path.isdir(os.path.dirname(catdir)):
-   raise
-
catdir_lock = AsynchronousLock(path=catdir, 
scheduler=self.scheduler)
-   yield catdir_lock.async_start()
-   yield catdir_lock.async_wait()
+   builddir_lock = AsynchronousLock(path=dir_path, 
scheduler=self.scheduler)
+   result = self.scheduler.create_future()
 
-   self._assert_lock(catdir_lock)
+   def catdir_locked(catdir_lock):
+   try:
+   self._assert_lock(catdir_lock)
+   except AssertionError as e:
+   result.set_exception(e)
+   return
+
+   try:
+   portage.util.ensure_dirs(catdir,
+   gid=portage.portage_gid,
+   mode=0o70, mask=0)
+   except PortageException as e:
+   if not os.path.isdir(catdir):
+   result.set_exception(e)
+   return
+
+   builddir_lock.addExitListener(builddir_locked)
+   builddir_lock.start()
+
+   def builddir_locked(builddir_lock):
+   try:
+   self._assert_lock(builddir_lock)
+   except AssertionError as e:
+   catdir_lock.async_unlock.add_done_callback(
+   functools.partial(catdir_unlocked, 
exception=e))
+   return
+
+   self._lock_obj = builddir_lock
+   self.locked = True
+   self.settings['PORTAGE_BUILDDIR_LOCKED'] = '1'
+   
catdir_lock.async_unlock().add_done_callback(catdir_unlocked)
+
+   def catdir_unlocked(future, exception=None):
+   if not (exception is None and future.exception() is 
None):
+   result.set_exception(exception or 
future.exception())
+   else:
+   result.set_result(None)
 
try:
-   portage.util.ensure_dirs(catdir,
+   portage.util.ensure_dirs(os.path.dirname(catdir),
gid=portage.portage_gid,
mode=0o70, mask=0)
except PortageException:
-   if not os.path.isdir(catdir):
+   if not os.path.isdir(os.path.dirname(catdir)):
raise
 
-   builddir_lock = AsynchronousLock(path=dir_path, 
scheduler=self.scheduler)
-   yield builddir_lock.async_start()
-   yield builddir_lock.async_wait()
-
-   

[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: 044012ffdbe8e946712fa63da9c03d31d8e1047d
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:53:06 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:46 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=044012ff

Revert "CompositeTask: call self.cancel() for _start_task CancelledError"

This reverts commit 1c681e0cc783ca241b1f2e1c782fccd8f1aac769.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/CompositeTask.py | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/lib/_emerge/CompositeTask.py b/lib/_emerge/CompositeTask.py
index 2ad1d783d..21129758a 100644
--- a/lib/_emerge/CompositeTask.py
+++ b/lib/_emerge/CompositeTask.py
@@ -119,7 +119,7 @@ class CompositeTask(AsynchronousTask):
try:
future.result()
except asyncio.CancelledError:
-   self.cancel()
+   self.cancelled = True
self._was_cancelled()
self._async_wait()
 



[gentoo-commits] proj/portage:master commit in: lib/_emerge/, lib/portage/util/_async/, lib/portage/package/ebuild/_config/, ...

2020-04-07 Thread Zac Medico
commit: 17df30bdfb72a157f9e34f3c2efa1e59389861d4
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:34:56 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:45 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=17df30bd

Revert "Rename PORTAGE_LOG_FILTER_FILE_CMD from PORTAGE_LOG_FILTER_FILE"

This reverts commit e24859eaa03ec86e10d842296f5570dd98bed4b7.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/AbstractEbuildProcess.py   | 2 +-
 lib/_emerge/EbuildPhase.py | 2 +-
 lib/portage/package/ebuild/_config/special_env_vars.py | 4 ++--
 lib/portage/util/_async/BuildLogger.py | 2 +-
 man/make.conf.5| 2 +-
 5 files changed, 6 insertions(+), 6 deletions(-)

diff --git a/lib/_emerge/AbstractEbuildProcess.py 
b/lib/_emerge/AbstractEbuildProcess.py
index cc1ea0f1a..6b2c2f81b 100644
--- a/lib/_emerge/AbstractEbuildProcess.py
+++ b/lib/_emerge/AbstractEbuildProcess.py
@@ -181,7 +181,7 @@ class AbstractEbuildProcess(SpawnProcess):
null_fd = os.open('/dev/null', os.O_RDONLY)
self.fd_pipes[0] = null_fd
 
-   self.log_filter_file = 
self.settings.get('PORTAGE_LOG_FILTER_FILE_CMD')
+   self.log_filter_file = 
self.settings.get('PORTAGE_LOG_FILTER_FILE')
 
try:
yield SpawnProcess._async_start(self)

diff --git a/lib/_emerge/EbuildPhase.py b/lib/_emerge/EbuildPhase.py
index fbb040ffd..927a74b98 100644
--- a/lib/_emerge/EbuildPhase.py
+++ b/lib/_emerge/EbuildPhase.py
@@ -420,7 +420,7 @@ class EbuildPhase(CompositeTask):
if log_path:
build_logger = 
BuildLogger(env=self.settings.environ(),
log_path=log_path,
-   
log_filter_file=self.settings.get('PORTAGE_LOG_FILTER_FILE_CMD'),
+   
log_filter_file=self.settings.get('PORTAGE_LOG_FILTER_FILE'),
scheduler=self.scheduler)
yield build_logger.async_start()
log_file = build_logger.stdin

diff --git a/lib/portage/package/ebuild/_config/special_env_vars.py 
b/lib/portage/package/ebuild/_config/special_env_vars.py
index c6f88f08c..dd8105123 100644
--- a/lib/portage/package/ebuild/_config/special_env_vars.py
+++ b/lib/portage/package/ebuild/_config/special_env_vars.py
@@ -175,7 +175,7 @@ environ_filter += [
"PORTAGE_RO_DISTDIRS",
"PORTAGE_RSYNC_EXTRA_OPTS", "PORTAGE_RSYNC_OPTS",
"PORTAGE_RSYNC_RETRIES", "PORTAGE_SSH_OPTS", "PORTAGE_SYNC_STALE",
-   "PORTAGE_USE", "PORTAGE_LOG_FILTER_FILE_CMD",
+   "PORTAGE_USE", "PORTAGE_LOG_FILTER_FILE",
"PORTAGE_LOGDIR", "PORTAGE_LOGDIR_CLEAN",
"QUICKPKG_DEFAULT_OPTS", "REPOMAN_DEFAULT_OPTS",
"RESUMECOMMAND", "RESUMECOMMAND_FTP",
@@ -205,7 +205,7 @@ default_globals = {
 }
 
 validate_commands = ('PORTAGE_BZIP2_COMMAND', 'PORTAGE_BUNZIP2_COMMAND',
-   'PORTAGE_LOG_FILTER_FILE_CMD',
+   'PORTAGE_LOG_FILTER_FILE',
 )
 
 # To enhance usability, make some vars case insensitive

diff --git a/lib/portage/util/_async/BuildLogger.py 
b/lib/portage/util/_async/BuildLogger.py
index 49f1321fb..4873d9750 100644
--- a/lib/portage/util/_async/BuildLogger.py
+++ b/lib/portage/util/_async/BuildLogger.py
@@ -14,7 +14,7 @@ class BuildLogger(AsynchronousTask):
Write to a log file, with compression support provided by PipeLogger.
If the log_filter_file parameter is specified, then it is interpreted
as a command to execute which filters log output (see the
-   PORTAGE_LOG_FILTER_FILE_CMD variable in make.conf(5)). The stdin 
property
+   PORTAGE_LOG_FILTER_FILE variable in make.conf(5)). The stdin property
provides access to a writable binary file stream (refers to a pipe)
that log content should be written to (usually redirected from
subprocess stdout and stderr streams).

diff --git a/man/make.conf.5 b/man/make.conf.5
index 467a9d394..baecd283a 100644
--- a/man/make.conf.5
+++ b/man/make.conf.5
@@ -979,7 +979,7 @@ with an integer pid. For example, a value of "ionice \-c 3 
\-p \\${PID}"
 will set idle io priority. For more information about ionice, see
 \fBionice\fR(1). This variable is unset by default.
 .TP
-.B PORTAGE_LOG_FILTER_FILE_CMD
+.B PORTAGE_LOG_FILTER_FILE
 This variable specifies a command that filters build log output to a
 log file. In order to filter ANSI escape codes from build logs,
 \fBansifilter\fR(1) is a convenient setting for this variable.



[gentoo-commits] proj/portage:master commit in: lib/portage/util/_async/, lib/portage/tests/process/

2020-04-07 Thread Zac Medico
commit: f1e9389d64b6ded41d0dac99979a049cfa27e75c
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:00:11 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:48 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=f1e9389d

Revert "PipeLogger: non-blocking write to pipe (bug 709746)"

This reverts commit 27712651aa7014a960b012dc89457df09677edc1.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/portage/tests/process/test_PopenProcess.py | 41 +---
 lib/portage/util/_async/PipeLogger.py  | 67 +-
 2 files changed, 14 insertions(+), 94 deletions(-)

diff --git a/lib/portage/tests/process/test_PopenProcess.py 
b/lib/portage/tests/process/test_PopenProcess.py
index d4e97f210..ed506b814 100644
--- a/lib/portage/tests/process/test_PopenProcess.py
+++ b/lib/portage/tests/process/test_PopenProcess.py
@@ -9,8 +9,6 @@ from portage.tests import TestCase
 from portage.util._async.PipeLogger import PipeLogger
 from portage.util._async.PopenProcess import PopenProcess
 from portage.util._eventloop.global_event_loop import global_event_loop
-from portage.util.futures._asyncio.streams import _reader
-from portage.util.futures.compat_coroutine import coroutine, coroutine_return
 from _emerge.PipeReader import PipeReader
 
 class PopenPipeTestCase(TestCase):
@@ -75,41 +73,8 @@ class PopenPipeTestCase(TestCase):
 
return content.decode('ascii', 'replace')
 
-   @coroutine
-   def _testPipeLoggerToPipe(self, test_string, loop=None):
-   """
-   Test PipeLogger writing to a pipe connected to a PipeReader.
-   This verifies that PipeLogger does not deadlock when writing
-   to a pipe that's drained by a PipeReader running in the same
-   process (requires non-blocking write).
-   """
-
-   producer = PopenProcess(proc=subprocess.Popen(
-   ["bash", "-c", self._echo_cmd % test_string],
-   stdout=subprocess.PIPE, stderr=subprocess.STDOUT),
-   scheduler=loop)
-
-   pr, pw = os.pipe()
-
-   consumer = producer.pipe_reader = PipeLogger(background=True,
-   input_fd=producer.proc.stdout,
-   log_file_path=os.fdopen(pw, 'wb', 0))
-
-   reader = _reader(pr, loop=loop)
-   yield producer.async_start()
-   content = yield reader
-   yield producer.async_wait()
-   yield consumer.async_wait()
-
-   self.assertEqual(producer.returncode, os.EX_OK)
-   self.assertEqual(consumer.returncode, os.EX_OK)
-
-   coroutine_return(content.decode('ascii', 'replace'))
-
def testPopenPipe(self):
-   loop = global_event_loop()
-
-   for x in (1, 2, 5, 6, 7, 8, 2**5, 2**10, 2**12, 2**13, 2**14, 
2**15, 2**16):
+   for x in (1, 2, 5, 6, 7, 8, 2**5, 2**10, 2**12, 2**13, 2**14):
test_string = x * "a"
output = self._testPipeReader(test_string)
self.assertEqual(test_string, output,
@@ -118,7 +83,3 @@ class PopenPipeTestCase(TestCase):
output = self._testPipeLogger(test_string)
self.assertEqual(test_string, output,
"x = %s, len(output) = %s" % (x, len(output)))
-
-   output = 
loop.run_until_complete(self._testPipeLoggerToPipe(test_string, loop=loop))
-   self.assertEqual(test_string, output,
-   "x = %s, len(output) = %s" % (x, len(output)))

diff --git a/lib/portage/util/_async/PipeLogger.py 
b/lib/portage/util/_async/PipeLogger.py
index 6b03988a1..a4258f350 100644
--- a/lib/portage/util/_async/PipeLogger.py
+++ b/lib/portage/util/_async/PipeLogger.py
@@ -8,9 +8,6 @@ import sys
 
 import portage
 from portage import os, _encodings, _unicode_encode
-from portage.util.futures import asyncio
-from portage.util.futures.compat_coroutine import coroutine
-from portage.util.futures.unix_events import _set_nonblocking
 from _emerge.AbstractPollTask import AbstractPollTask
 
 class PipeLogger(AbstractPollTask):
@@ -24,15 +21,13 @@ class PipeLogger(AbstractPollTask):
"""
 
__slots__ = ("input_fd", "log_file_path", "stdout_fd") + \
-   ("_io_loop_task", "_log_file", "_log_file_real")
+   ("_log_file", "_log_file_real")
 
def _start(self):
 
log_file_path = self.log_file_path
-   if hasattr(log_file_path, 'write'):
-   self._log_file = log_file_path
-   _set_nonblocking(self._log_file.fileno())
-   elif log_file_path is not None:
+   if log_file_path is not None:
+
self._log_file = 

[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: 7e2918896d8dd84e07082bba734d3ce8429ba36d
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:54:27 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:47 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=7e291889

Revert "SpawnProcess: make _main cancel pipe_logger when appropriate"

This reverts commit 6eb6500435c80837f106d3f9f9f6bb246ff00c16.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/SpawnProcess.py | 9 ++---
 1 file changed, 2 insertions(+), 7 deletions(-)

diff --git a/lib/_emerge/SpawnProcess.py b/lib/_emerge/SpawnProcess.py
index 941b56683..aef000e22 100644
--- a/lib/_emerge/SpawnProcess.py
+++ b/lib/_emerge/SpawnProcess.py
@@ -155,13 +155,8 @@ class SpawnProcess(SubProcess):
 
@coroutine
def _main(self, pipe_logger):
-   try:
-   if pipe_logger.poll() is None:
-   yield pipe_logger.async_wait()
-   except asyncio.CancelledError:
-   if pipe_logger.poll() is None:
-   pipe_logger.cancel()
-   raise
+   if pipe_logger.poll() is None:
+   yield pipe_logger.async_wait()
 
def _main_exit(self, main_task):
try:



[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: 66c66190724b6d58961827c5d642c59db10fcdb1
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:47:12 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:45 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=66c66190

Revert "SpawnProcess: cancel _main_task in _unregister (bug 711174)"

This reverts commit 97587a47fcd00d070c081ad3933e4036cf0f8e81.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/SpawnProcess.py | 2 --
 1 file changed, 2 deletions(-)

diff --git a/lib/_emerge/SpawnProcess.py b/lib/_emerge/SpawnProcess.py
index bf5c45189..34668b287 100644
--- a/lib/_emerge/SpawnProcess.py
+++ b/lib/_emerge/SpawnProcess.py
@@ -218,8 +218,6 @@ class SpawnProcess(SubProcess):
if self.cgroup is not None:
self._cgroup_cleanup()
self.cgroup = None
-   if self._main_task is not None:
-   self._main_task.done() or self._main_task.cancel()
 
def _cancel(self):
SubProcess._cancel(self)



[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: 79a46f6ebdc9dc2b9bec611c8b88037b2ffe43d6
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:50:21 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:46 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=79a46f6e

Revert "EbuildBuildDir: cancel current tasks for CancelledError"

This reverts commit 899d5e61010a85702e7c83506d2214ede179c964.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/EbuildBuildDir.py | 46 +++
 1 file changed, 16 insertions(+), 30 deletions(-)

diff --git a/lib/_emerge/EbuildBuildDir.py b/lib/_emerge/EbuildBuildDir.py
index f1c49f041..77dbff1fb 100644
--- a/lib/_emerge/EbuildBuildDir.py
+++ b/lib/_emerge/EbuildBuildDir.py
@@ -6,7 +6,6 @@ from _emerge.AsynchronousLock import AsynchronousLock
 import portage
 from portage import os
 from portage.exception import PortageException
-from portage.util.futures import asyncio
 from portage.util.futures.compat_coroutine import coroutine
 from portage.util.SlotObject import SlotObject
 
@@ -70,29 +69,22 @@ class EbuildBuildDir(SlotObject):
raise
 
catdir_lock = AsynchronousLock(path=catdir, 
scheduler=self.scheduler)
-   builddir_lock = AsynchronousLock(path=dir_path, 
scheduler=self.scheduler)
-   try:
-   yield catdir_lock.async_start()
-   yield catdir_lock.async_wait()
+   yield catdir_lock.async_start()
+   yield catdir_lock.async_wait()
 
-   self._assert_lock(catdir_lock)
+   self._assert_lock(catdir_lock)
 
-   try:
-   portage.util.ensure_dirs(catdir,
-   gid=portage.portage_gid,
-   mode=0o70, mask=0)
-   except PortageException:
-   if not os.path.isdir(catdir):
-   raise
-
-   yield builddir_lock.async_start()
-   yield builddir_lock.async_wait()
-   except asyncio.CancelledError:
-   if catdir_lock.poll() is None:
-   catdir_lock.cancel()
-   if builddir_lock.poll() is None:
-   builddir_lock.cancel()
-   raise
+   try:
+   portage.util.ensure_dirs(catdir,
+   gid=portage.portage_gid,
+   mode=0o70, mask=0)
+   except PortageException:
+   if not os.path.isdir(catdir):
+   raise
+
+   builddir_lock = AsynchronousLock(path=dir_path, 
scheduler=self.scheduler)
+   yield builddir_lock.async_start()
+   yield builddir_lock.async_wait()
 
try:
self._assert_lock(builddir_lock)
@@ -121,14 +113,8 @@ class EbuildBuildDir(SlotObject):
self.settings.pop('PORTAGE_BUILDDIR_LOCKED', None)
catdir_lock = AsynchronousLock(
path=self._catdir, scheduler=self.scheduler)
-   try:
-   yield catdir_lock.async_start()
-   yield catdir_lock.async_wait()
-   except asyncio.CancelledError:
-   if catdir_lock.poll() is None:
-   catdir_lock.cancel()
-   raise
-
+   yield catdir_lock.async_start()
+   yield catdir_lock.async_wait()
if catdir_lock.returncode == os.EX_OK:
try:
os.rmdir(self._catdir)



[gentoo-commits] proj/portage:master commit in: lib/_emerge/, lib/portage/util/_async/, lib/portage/tests/util/futures/, ...

2020-04-07 Thread Zac Medico
commit: 28adac2b67f46e11b4cf9116761d888e91e55f3c
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 05:00:56 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:48 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=28adac2b

Revert "SpawnProcess: use async_start method (bug 709746)"

This reverts commit 5c40c3e7ec180c9c7d1eea521d69487177c7f519.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/AbstractEbuildProcess.py  |  2 +-
 lib/_emerge/AsynchronousLock.py   | 15 +++
 lib/_emerge/BinpkgExtractorAsync.py   |  9 ++---
 lib/_emerge/BinpkgFetcher.py  |  9 ++---
 lib/_emerge/EbuildFetcher.py  |  9 ++---
 lib/_emerge/SpawnProcess.py   |  8 ++--
 lib/portage/dbapi/bintree.py  |  4 ++--
 lib/portage/tests/util/futures/test_iter_completed.py |  6 +-
 lib/portage/util/_async/AsyncFunction.py  |  9 ++---
 lib/portage/util/_async/FileDigester.py   |  9 ++---
 10 files changed, 19 insertions(+), 61 deletions(-)

diff --git a/lib/_emerge/AbstractEbuildProcess.py 
b/lib/_emerge/AbstractEbuildProcess.py
index 09b76830d..fd8a40cc1 100644
--- a/lib/_emerge/AbstractEbuildProcess.py
+++ b/lib/_emerge/AbstractEbuildProcess.py
@@ -182,7 +182,7 @@ class AbstractEbuildProcess(SpawnProcess):
self.fd_pipes[0] = null_fd
 
try:
-   yield SpawnProcess._async_start(self)
+   SpawnProcess._start(self)
finally:
if null_fd is not None:
os.close(null_fd)

diff --git a/lib/_emerge/AsynchronousLock.py b/lib/_emerge/AsynchronousLock.py
index 9efaaceac..aed1bcb15 100644
--- a/lib/_emerge/AsynchronousLock.py
+++ b/lib/_emerge/AsynchronousLock.py
@@ -1,4 +1,4 @@
-# Copyright 2010-2020 Gentoo Authors
+# Copyright 2010-2018 Gentoo Foundation
 # Distributed under the terms of the GNU General Public License v2
 
 import fcntl
@@ -21,7 +21,6 @@ from portage.exception import TryAgain
 from portage.localization import _
 from portage.locks import lockfile, unlockfile
 from portage.util import writemsg_level
-from portage.util.futures.compat_coroutine import coroutine
 from _emerge.AbstractPollTask import AbstractPollTask
 from _emerge.AsynchronousTask import AsynchronousTask
 from _emerge.SpawnProcess import SpawnProcess
@@ -44,10 +43,6 @@ class AsynchronousLock(AsynchronousTask):
_use_process_by_default = True
 
def _start(self):
-   self.scheduler.run_until_complete(self._async_start())
-
-   @coroutine
-   def _async_start(self):
 
if not self._force_async:
try:
@@ -70,7 +65,7 @@ class AsynchronousLock(AsynchronousTask):
_force_dummy=self._force_dummy)
 
self._imp.addExitListener(self._imp_exit)
-   yield self._imp.async_start()
+   self._imp.start()
 
def _imp_exit(self, imp):
# call exit listeners
@@ -188,10 +183,6 @@ class _LockProcess(AbstractPollTask):
('_acquired', '_kill_test', '_proc', '_files', '_unlock_future')
 
def _start(self):
-   self.scheduler.run_until_complete(self._async_start())
-
-   @coroutine
-   def _async_start(self):
in_pr, in_pw = os.pipe()
out_pr, out_pw = os.pipe()
self._files = {}
@@ -220,7 +211,7 @@ class _LockProcess(AbstractPollTask):
fd_pipes={0:out_pr, 1:in_pw, 
2:sys.__stderr__.fileno()},
scheduler=self.scheduler)
self._proc.addExitListener(self._proc_exit)
-   yield self._proc.async_start()
+   self._proc.start()
os.close(out_pr)
os.close(in_pw)
 

diff --git a/lib/_emerge/BinpkgExtractorAsync.py 
b/lib/_emerge/BinpkgExtractorAsync.py
index 5f4caa794..3733bdeb5 100644
--- a/lib/_emerge/BinpkgExtractorAsync.py
+++ b/lib/_emerge/BinpkgExtractorAsync.py
@@ -1,4 +1,4 @@
-# Copyright 1999-2020 Gentoo Authors
+# Copyright 1999-2013 Gentoo Foundation
 # Distributed under the terms of the GNU General Public License v2
 
 import logging
@@ -10,7 +10,6 @@ from portage.util.compression_probe import (
compression_probe,
_compressors,
 )
-from portage.util.futures.compat_coroutine import coroutine
 from portage.process import find_binary
 from portage.util import (
shlex_split,
@@ -28,10 +27,6 @@ class BinpkgExtractorAsync(SpawnProcess):
_shell_binary = portage.const.BASH_BINARY
 
def _start(self):
-   self.scheduler.run_until_complete(self._async_start())
-
-   @coroutine
-   def _async_start(self):

[gentoo-commits] proj/portage:master commit in: lib/_emerge/

2020-04-07 Thread Zac Medico
commit: c2ffa9413bbad9d56cbed6e1d779c204fafafc69
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:48:05 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:45 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=c2ffa941

Revert "_BinpkgFetcherProcess: fix async_lock event loop recursion (bug 711178)"

This reverts commit 1681309f252a4e91d7256b895a9af26ef82a9b30.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/BinpkgFetcher.py | 32 +++-
 1 file changed, 15 insertions(+), 17 deletions(-)

diff --git a/lib/_emerge/BinpkgFetcher.py b/lib/_emerge/BinpkgFetcher.py
index e788cb05d..640eead91 100644
--- a/lib/_emerge/BinpkgFetcher.py
+++ b/lib/_emerge/BinpkgFetcher.py
@@ -16,7 +16,6 @@ import portage
 from portage import os
 from portage.util._async.AsyncTaskFuture import AsyncTaskFuture
 from portage.util._pty import _create_pty_or_pipe
-from portage.util.futures import asyncio
 from portage.util.futures.compat_coroutine import coroutine
 
 if sys.hexversion >= 0x300:
@@ -206,7 +205,6 @@ class _BinpkgFetcherProcess(SpawnProcess):
except OSError:
pass
 
-   @coroutine
def async_lock(self):
"""
This raises an AlreadyLocked exception if lock() is called
@@ -217,22 +215,22 @@ class _BinpkgFetcherProcess(SpawnProcess):
if self._lock_obj is not None:
raise self.AlreadyLocked((self._lock_obj,))
 
-   async_lock = self._lock_obj = 
AsynchronousLock(path=self.pkg_path,
+   result = self.scheduler.create_future()
+
+   def acquired_lock(async_lock):
+   if async_lock.wait() == os.EX_OK:
+   self.locked = True
+   result.set_result(None)
+   else:
+   result.set_exception(AssertionError(
+   "AsynchronousLock failed with 
returncode %s"
+   % (async_lock.returncode,)))
+
+   self._lock_obj = AsynchronousLock(path=self.pkg_path,
scheduler=self.scheduler)
-   try:
-   yield async_lock.async_start()
-   yield async_lock.async_wait()
-   except asyncio.CancelledError:
-   if async_lock.poll() is None:
-   async_lock.cancel()
-   raise
-
-   if async_lock.returncode != os.EX_OK:
-   raise AssertionError(
-   "AsynchronousLock failed with returncode %s"
-   % (async_lock.returncode,))
-
-   self.locked = True
+   self._lock_obj.addExitListener(acquired_lock)
+   self._lock_obj.start()
+   return result
 
class AlreadyLocked(portage.exception.PortageException):
pass



[gentoo-commits] proj/portage:master commit in: lib/portage/util/_async/

2020-04-07 Thread Zac Medico
commit: 4122a1e12884288e1d578a0cc8cfb400f00b8199
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:51:23 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:46 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=4122a1e1

Revert "AsyncScheduler: cancel task after _task_coroutine CancelledError"

This reverts commit 27a6ee3d09ff79b6addb2696a10fcc3f46e5ca91.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/portage/util/_async/AsyncScheduler.py | 1 -
 1 file changed, 1 deletion(-)

diff --git a/lib/portage/util/_async/AsyncScheduler.py 
b/lib/portage/util/_async/AsyncScheduler.py
index c31bda5f2..b9070061a 100644
--- a/lib/portage/util/_async/AsyncScheduler.py
+++ b/lib/portage/util/_async/AsyncScheduler.py
@@ -86,7 +86,6 @@ class AsyncScheduler(AsynchronousTask, PollScheduler):
try:
future.result()
except asyncio.CancelledError:
-   task.cancel()
self.cancel()
self._task_exit(task)
 



[gentoo-commits] proj/portage:master commit in: lib/portage/util/_async/, lib/_emerge/, lib/portage/package/ebuild/_config/, ...

2020-04-07 Thread Zac Medico
commit: a0148f998ad81700f68402ab3f58140e6d32f57d
Author: Zac Medico  gentoo  org>
AuthorDate: Wed Apr  8 04:48:56 2020 +
Commit: Zac Medico  gentoo  org>
CommitDate: Wed Apr  8 05:29:46 2020 +
URL:https://gitweb.gentoo.org/proj/portage.git/commit/?id=a0148f99

Revert "Support PORTAGE_LOG_FILTER_FILE (bug 709746)"

This reverts commit 73f72f526a66b9953a46868cc1390fde2820997f.

Bug: https://bugs.gentoo.org/716636
Signed-off-by: Zac Medico  gentoo.org>

 lib/_emerge/AbstractEbuildProcess.py   |   2 -
 lib/_emerge/EbuildPhase.py |  36 ++-
 lib/_emerge/SpawnProcess.py|  32 ++
 .../package/ebuild/_config/special_env_vars.py |   8 +-
 lib/portage/util/_async/BuildLogger.py | 116 -
 lib/portage/util/_async/SchedulerInterface.py  |  32 +-
 man/make.conf.5|   7 +-
 7 files changed, 20 insertions(+), 213 deletions(-)

diff --git a/lib/_emerge/AbstractEbuildProcess.py 
b/lib/_emerge/AbstractEbuildProcess.py
index 6b2c2f81b..09b76830d 100644
--- a/lib/_emerge/AbstractEbuildProcess.py
+++ b/lib/_emerge/AbstractEbuildProcess.py
@@ -181,8 +181,6 @@ class AbstractEbuildProcess(SpawnProcess):
null_fd = os.open('/dev/null', os.O_RDONLY)
self.fd_pipes[0] = null_fd
 
-   self.log_filter_file = 
self.settings.get('PORTAGE_LOG_FILTER_FILE')
-
try:
yield SpawnProcess._async_start(self)
finally:

diff --git a/lib/_emerge/EbuildPhase.py b/lib/_emerge/EbuildPhase.py
index 927a74b98..f6b380e05 100644
--- a/lib/_emerge/EbuildPhase.py
+++ b/lib/_emerge/EbuildPhase.py
@@ -26,8 +26,6 @@ from portage.package.ebuild.prepare_build_dirs import 
(_prepare_workdir,
 from portage.util.futures.compat_coroutine import coroutine, coroutine_return
 from portage.util import writemsg
 from portage.util._async.AsyncTaskFuture import AsyncTaskFuture
-from portage.util._async.BuildLogger import BuildLogger
-from portage.util.futures import asyncio
 from portage.util.futures.executor.fork import ForkExecutor
 
 try:
@@ -132,7 +130,7 @@ class EbuildPhase(CompositeTask):
# Force background=True for this header since it's 
intended
# for the log and it doesn't necessarily need to be 
visible
# elsewhere.
-   yield self._elog('einfo', msg, background=True)
+   self._elog('einfo', msg, background=True)
 
if self.phase == 'package':
if 'PORTAGE_BINPKG_TMPFILE' not in self.settings:
@@ -394,7 +392,6 @@ class EbuildPhase(CompositeTask):
self.returncode = 1
self.wait()
 
-   @coroutine
def _elog(self, elog_funcname, lines, background=None):
if background is None:
background = self.background
@@ -411,30 +408,11 @@ class EbuildPhase(CompositeTask):
portage.output.havecolor = global_havecolor
msg = out.getvalue()
if msg:
-   build_logger = None
-   try:
-   log_file = None
-   log_path = None
-   if self.settings.get("PORTAGE_BACKGROUND") != 
"subprocess":
-   log_path = 
self.settings.get("PORTAGE_LOG_FILE")
-   if log_path:
-   build_logger = 
BuildLogger(env=self.settings.environ(),
-   log_path=log_path,
-   
log_filter_file=self.settings.get('PORTAGE_LOG_FILTER_FILE'),
-   scheduler=self.scheduler)
-   yield build_logger.async_start()
-   log_file = build_logger.stdin
-
-   yield self.scheduler.async_output(msg, 
log_file=log_file,
-   background=background)
-
-   if build_logger is not None:
-   build_logger.stdin.close()
-   yield build_logger.async_wait()
-   except asyncio.CancelledError:
-   if build_logger is not None:
-   build_logger.cancel()
-   raise
+   log_path = None
+   if self.settings.get("PORTAGE_BACKGROUND") != 
"subprocess":
+   log_path = self.settings.get("PORTAGE_LOG_FILE")
+   self.scheduler.output(msg, log_path=log_path,
+   background=background)
 
 
 class 

[gentoo-commits] repo/gentoo:master commit in: x11-libs/gtksourceview/

2020-04-07 Thread Mart Raudsepp
commit: b0e8b3173f503680b941e6af7f87e1c7a00ff79e
Author: Mart Raudsepp  gentoo  org>
AuthorDate: Wed Apr  8 05:53:34 2020 +
Commit: Mart Raudsepp  gentoo  org>
CommitDate: Wed Apr  8 05:53:34 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=b0e8b317

x11-libs/gtksourceview: bump to 4.4.0

Package-Manager: Portage-2.3.84, Repoman-2.3.20
Signed-off-by: Mart Raudsepp  gentoo.org>

 x11-libs/gtksourceview/Manifest   |  1 +
 x11-libs/gtksourceview/gtksourceview-4.4.0.ebuild | 68 +++
 2 files changed, 69 insertions(+)

diff --git a/x11-libs/gtksourceview/Manifest b/x11-libs/gtksourceview/Manifest
index c55083f2ad5..1e0f547a014 100644
--- a/x11-libs/gtksourceview/Manifest
+++ b/x11-libs/gtksourceview/Manifest
@@ -1,3 +1,4 @@
 DIST gtksourceview-2.10.5.tar.bz2 1253321 BLAKE2B 
810a3eeca69bab4356b21c64129bb852e00d02c7937ad4a2ce3af9e48700da943d8d6834efcce9810dd49a54f39d4a074dc086a557128da51a593b2f23e58d48
 SHA512 
6f64acef6196bfc5953e0b148d7e460d366073b5e21367c01b01fc4d1c86ffe8aca71ecd77cf0814e47d8fc3085495f25bbbdc69e746987b02fd02fcda64886d
 DIST gtksourceview-3.24.11.tar.xz 1438232 BLAKE2B 
a25762255a12887c8151465689e3acbd5864a6638044500acd087832888a092b8aad5d885d31c9dbe057ce183510afa2342bccb2a2675719dbba7e82be72368a
 SHA512 
3490b34c6432a2e2ef292ad5bf982fdd22d33b1472434549b4ea8ddae0fc8808e128ef947e4d0dcb41e8de5e601b202f52532fa11d35050acfc42f9936b2
 DIST gtksourceview-4.2.0.tar.xz 1410764 BLAKE2B 
8f20a762c16a0abc47ff191a2ea4d6b44a397cabee056e98263d0ba59cbc7207ac72341a630aa83fe7855804bd6add77e0d93e706ac9561c9577843f17e00246
 SHA512 
f2350b1e7042309c01be0feda6059d788a7ef55c4ccd48e16b4c92a71292ed6f92243455ca42aa0950db61de8d68f4a76f4fac46cd46316b690bcef1ea34c641
+DIST gtksourceview-4.4.0.tar.xz 1105776 BLAKE2B 
ef4ed4ed15435daba60795598ba41624b2680b0518246d5d6ade3630cb96e2bac96fea08105e72db7b5a07e714f9270ce27c11e9448fd1b21e8d3942989b2255
 SHA512 
068e723525290c5356c5ce3f5e5b5b8ecc9f7b1ff2f8234da247d1a84bed63ff5601cad6550981720859286e107705ec25cc7793b754ada164ec6569df0df9eb

diff --git a/x11-libs/gtksourceview/gtksourceview-4.4.0.ebuild 
b/x11-libs/gtksourceview/gtksourceview-4.4.0.ebuild
new file mode 100644
index 000..7de4201a29d
--- /dev/null
+++ b/x11-libs/gtksourceview/gtksourceview-4.4.0.ebuild
@@ -0,0 +1,68 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit gnome.org meson vala virtualx xdg
+
+DESCRIPTION="A text widget implementing syntax highlighting and other features"
+HOMEPAGE="https://wiki.gnome.org/Projects/GtkSourceView;
+
+LICENSE="LGPL-2.1+"
+SLOT="4"
+
+IUSE="glade gtk-doc +introspection +vala"
+REQUIRED_USE="vala? ( introspection )"
+
+KEYWORDS="~alpha ~amd64 ~arm ~arm64 ~ia64 ~mips ~ppc ~ppc64 ~sparc ~x86 
~amd64-linux ~x86-linux ~ppc-macos ~x86-solaris"
+
+RDEPEND="
+   >=dev-libs/glib-2.48:2
+   >=x11-libs/gtk+-3.22:3[introspection?]
+   >=dev-libs/libxml2-2.6:2
+   glade? ( >=dev-util/glade-3.9:3.10 )
+   introspection? ( >=dev-libs/gobject-introspection-1.42.0:= )
+   >=dev-libs/fribidi-0.19.7
+"
+DEPEND="${RDEPEND}"
+BDEPEND="
+   dev-util/glib-utils
+   gtk-doc? ( >=dev-util/gtk-doc-1.25
+   app-text/docbook-xml-dtd:4.3 )
+   >=sys-devel/gettext-0.19.8
+   virtual/pkgconfig
+   vala? ( $(vala_depend) )
+"
+
+src_prepare() {
+   use vala && vala_src_prepare
+   xdg_src_prepare
+}
+
+src_configure() {
+   local emesonargs=(
+   $(meson_use glade glade_catalog)
+   -Dinstall_tests=false
+   $(meson_use introspection gir)
+   $(meson_use vala vapi)
+   $(meson_use gtk-doc gtk_doc)
+   )
+   meson_src_configure
+}
+
+src_test() {
+   virtx meson_src_test
+}
+
+src_install() {
+   meson_src_install
+
+   insinto /usr/share/${PN}-4/language-specs
+   doins "${FILESDIR}"/2.0/gentoo.lang
+
+   # Avoid conflict with gtksourceview:3.0 glade-catalog
+   # TODO: glade doesn't actually show multiple GtkSourceView widget 
collections, so with both installed, can't really be sure which ones are used
+   if use glade; then
+   mv "${ED}"/usr/share/glade/catalogs/gtksourceview.xml 
"${ED}"/usr/share/glade/catalogs/gtksourceview-${SLOT}.xml || die
+   fi
+}



[gentoo-commits] repo/gentoo:master commit in: media-libs/waffle/

2020-04-07 Thread Matt Turner
commit: f5c8b9272648d6eaecd6353972022836212d7cfb
Author: Matt Turner  gentoo  org>
AuthorDate: Wed Apr  8 03:39:22 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Wed Apr  8 03:40:34 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=f5c8b927

media-libs/waffle: Reapply patch to Generate WaffleConfig.cmake file

I mistakenly thought this was included in the 1.6.1 release.

Closes: https://bugs.gentoo.org/716130
Signed-off-by: Matt Turner  gentoo.org>

 media-libs/waffle/{waffle-1.6.1.ebuild => waffle-1.6.1-r1.ebuild} | 4 
 1 file changed, 4 insertions(+)

diff --git a/media-libs/waffle/waffle-1.6.1.ebuild 
b/media-libs/waffle/waffle-1.6.1-r1.ebuild
similarity index 94%
rename from media-libs/waffle/waffle-1.6.1.ebuild
rename to media-libs/waffle/waffle-1.6.1-r1.ebuild
index 1786f943ad9..bb76a7df510 100644
--- a/media-libs/waffle/waffle-1.6.1.ebuild
+++ b/media-libs/waffle/waffle-1.6.1-r1.ebuild
@@ -36,6 +36,10 @@ BDEPEND="
app-text/docbook-xml-dtd:4.2
 "
 
+PATCHES=(
+   
"${FILESDIR}"/${PN}-1.6.0-meson-Generate-cmake-config-and-version-files-if-mes.patch
+)
+
 MULTILIB_CHOST_TOOLS=(
/usr/bin/wflinfo$(get_exeext)
 )



[gentoo-commits] repo/gentoo:master commit in: sys-cluster/ceph/

2020-04-07 Thread Patrick McLean
commit: 9554f74ebb15e5ca8831de533bf35050bdb89fd4
Author: Patrick McLean  gentoo  org>
AuthorDate: Wed Apr  8 02:20:20 2020 +
Commit: Patrick McLean  gentoo  org>
CommitDate: Wed Apr  8 02:20:20 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=9554f74e

sys-cluster/cephi-15.2.0-r1: revbump add dep on libfmt (bug #716592)

Closes: https://bugs.gentoo.org/716592
Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Patrick McLean  gentoo.org>

 sys-cluster/ceph/{ceph-15.2.0.ebuild => ceph-15.2.0-r1.ebuild} | 1 +
 1 file changed, 1 insertion(+)

diff --git a/sys-cluster/ceph/ceph-15.2.0.ebuild 
b/sys-cluster/ceph/ceph-15.2.0-r1.ebuild
similarity index 99%
rename from sys-cluster/ceph/ceph-15.2.0.ebuild
rename to sys-cluster/ceph/ceph-15.2.0-r1.ebuild
index 2e8eff93d54..e59cae91a6c 100644
--- a/sys-cluster/ceph/ceph-15.2.0.ebuild
+++ b/sys-cluster/ceph/ceph-15.2.0-r1.ebuild
@@ -46,6 +46,7 @@ COMMON_DEPEND="
dev-libs/crypto++:=[static-libs?]
dev-libs/leveldb:=[snappy,static-libs?,tcmalloc(-)?]
dev-libs/libaio:=[static-libs?]
+   dev-libs/libfmt:=
dev-libs/libnl:3=[static-libs?]
dev-libs/libxml2:=[static-libs?]
dev-libs/xmlsec:=[!openssl?,!libressl?,static-libs?]



[gentoo-commits] proj/mozilla:master commit in: www-client/firefox/files/, www-client/firefox/

2020-04-07 Thread Jory Pratt
commit: 5ebd386a94bb8a99f5999dccd80dec422eaba17a
Author: Jory Pratt  gentoo  org>
AuthorDate: Wed Apr  8 02:00:54 2020 +
Commit: Jory Pratt  gentoo  org>
CommitDate: Wed Apr  8 02:00:54 2020 +
URL:https://gitweb.gentoo.org/proj/mozilla.git/commit/?id=5ebd386a

www-client/firefox: Drop xinput2, do not allow profile downgrades

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Jory Pratt  gentoo.org>

 www-client/firefox/files/firefox.sh| 24 +-
 ...{firefox-75.0.ebuild => firefox-75.0-r1.ebuild} |  0
 2 files changed, 1 insertion(+), 23 deletions(-)

diff --git a/www-client/firefox/files/firefox.sh 
b/www-client/firefox/files/firefox.sh
index c08d555..eb66a42 100644
--- a/www-client/firefox/files/firefox.sh
+++ b/www-client/firefox/files/firefox.sh
@@ -90,31 +90,9 @@ if [[ "$XDG_CURRENT_DESKTOP" == "GNOME" ]]; then
export GNOME_DISABLE_CRASH_DIALOG
 fi
 
-##
-## Enable Xinput2 (#617344)
-##
-
-# respect user settings
-MOZ_USE_XINPUT2=${MOZ_USE_XINPUT2:-auto}
-
-if [[ ${MOZ_USE_XINPUT2} == auto && -n ${WAYLAND_DISPLAY} ]]; then
-   # enabling XINPUT2 should be safe for all wayland users
-   MOZ_USE_XINPUT2=1
-elif [[ ${MOZ_USE_XINPUT2} == auto && ${XDG_CURRENT_DESKTOP^^} == KDE ]]; then
-   # XINPUT2 is known to cause problems for KWin users
-   MOZ_USE_XINPUT2=0
-elif [[ ${MOZ_USE_XINPUT2} == auto && ${XDG_CURRENT_DESKTOP^^} == LXQT ]]; then
-   # LXQt uses KWin
-   MOZ_USE_XINPUT2=0
-elif [[ ${MOZ_USE_XINPUT2} == auto ]]; then
-   # should work on Mate, Xfce, FluxBox, OpenBox and all the others ...
-   MOZ_USE_XINPUT2=1
-fi
-
-[[ ${MOZ_USE_XINPUT2} != 0 ]] && export MOZ_USE_XINPUT2=${MOZ_USE_XINPUT2}
 
 # Don't throw "old profile" dialog box.
-export MOZ_ALLOW_DOWNGRADE=1
+export MOZ_ALLOW_DOWNGRADE=0
 
 ##
 ## Route to the correct .desktop file to get proper

diff --git a/www-client/firefox/firefox-75.0.ebuild 
b/www-client/firefox/firefox-75.0-r1.ebuild
similarity index 100%
rename from www-client/firefox/firefox-75.0.ebuild
rename to www-client/firefox/firefox-75.0-r1.ebuild



[gentoo-commits] proj/mozilla:master commit in: www-client/firefox/files/icon/, www-client/firefox/, www-client/firefox/files/

2020-04-07 Thread Jory Pratt
commit: 293d8b191a3fdd7b724770fd6148bcba2230af1d
Author: Jory Pratt  gentoo  org>
AuthorDate: Wed Apr  8 01:55:58 2020 +
Commit: Jory Pratt  gentoo  org>
CommitDate: Wed Apr  8 01:55:58 2020 +
URL:https://gitweb.gentoo.org/proj/mozilla.git/commit/?id=293d8b19

www-client/firefox: Unbreak patchset, readd missing lto/llvm9 patches

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Jory Pratt  gentoo.org>

 www-client/firefox/Manifest|  93 -
 www-client/firefox/files/firefox-wayland.sh|   7 +
 www-client/firefox/files/firefox-x11.sh|   7 +
 www-client/firefox/files/firefox.sh| 128 
 www-client/firefox/files/gentoo-default-prefs.js-3 |   1 +
 www-client/firefox/files/icon/firefox-r1.desktop   | 230 +
 www-client/firefox/files/icon/firefox.desktop  |  10 -
 ...efox-75.0_beta10.ebuild => firefox-75.0.ebuild} | 145 +++--
 www-client/firefox/metadata.xml|   4 +-
 9 files changed, 593 insertions(+), 32 deletions(-)

diff --git a/www-client/firefox/Manifest b/www-client/firefox/Manifest
index c82cf49..83ee7b5 100644
--- a/www-client/firefox/Manifest
+++ b/www-client/firefox/Manifest
@@ -1,2 +1,93 @@
+DIST firefox-75.0-ach.xpi 503112 BLAKE2B 
c1fe6c4aae1b95276aa40bb40d1b684f5df73ba1203220699aa8b6d72ad93def1304d766dada23e371692d73e54de1575891aabb782619f7bd6190e1f18f62bc
 SHA512 
f46110cd85635978c1531a278b606eb412077f32b482442dfdecc46fb8dcedc216c9ec85f397f777c1ab000be838101aeeedade4d1c77efa53643c9e3718c29c
+DIST firefox-75.0-af.xpi 458561 BLAKE2B 
a4f0d601a8ffd2bbc9204a2cc3af90b7dd23961729657daf8d69ebf90dfed1417c1fab54080e1a0335242cb375c4c14379d09134c1aeb30ae497f0fd6cb36df5
 SHA512 
b4e386ba6f3986c2aa3aa8ca8d6a0afc266537c31dc7017de15fa0d2656db370fbbba4962e3f168e34475a2ef61c6a77b2e4ac5cbabda54f4b9d839ffb4c810d
+DIST firefox-75.0-an.xpi 515827 BLAKE2B 
0a18a6c3bb9ff3e3b35963e43c6d550e379a1977ee34e5e212b0484c69b929e07a7b012e8ead965ef5a030ecd7b79a16468e2fd4574899360855259f4941a735
 SHA512 
420fc7444edb4b0f2f8103ed516ef30f281c8cbac998aff91978117ec0b649281ce231cba8b45709960bab28ecb6539709a567941f2c98bad0d7eb5a4cd9f1c5
+DIST firefox-75.0-ar.xpi 589375 BLAKE2B 
55a1f528f59aff9c758415c2386b37b9b750ed375206957ef4cf9fc7c11bcab24875f6baddda1fc900354cffe053ed7f609c3b450c4baacaaea64a7529dc29ba
 SHA512 
8f0c790b706cbd92dbe475c8342a9da7bfc0ab4f4acccabb14dab7ac4f75f86b8689c93048ea6e4b2ef717b8e406ce6d24edd804969cd18794d66adee9f94c99
+DIST firefox-75.0-ast.xpi 504608 BLAKE2B 
dffb527979595b61fce405296ce6082246450925e5ba0a0ce98cb329a9f9df7742a30832f1e62cf67bc6f5caa228089ebb50eff1785df98aa86efb85078abf32
 SHA512 
fd85904a72881fb94d090f2dc28a55182270ae63a138aa9a912b6a2ed805012737014acaffa1971f0940ab7e80a1162bfda5865d112a644cfd9fdca941abee04
+DIST firefox-75.0-az.xpi 537769 BLAKE2B 
be5f344ac797430b8d88cec19061f56db191be09a6704124c63c82da16809bd69c0340597a99c6991521f6b8c9703c09547733262d7ecf4d0d2158fe79960ebc
 SHA512 
de826fd9059430f012b2f10f14333bb8b7e445c61b39df3f618822607e8ee924164db30cdd24461c0b62d29ce347391dcf0ece5734811f4de31e47f0f13ba1bd
+DIST firefox-75.0-be.xpi 637504 BLAKE2B 
0ba49e8f9e1f8a5e20aeca36194962e6a9c7b203a998e94a525ad766398cef356d1ba63d54a5f646698044b36836a94fbb15778c1fdb1a73310c35ebc93127aa
 SHA512 
6f240229061c48388cae251da362c73c32c19c0001f14c9556e2d3194d6b02b701c42b1e16babd574cd2b14f150b302b079dbf3f123c8c9b977720f65370d630
+DIST firefox-75.0-bg.xpi 603385 BLAKE2B 
cc25cda7b68239e2faa4e9df5557c8228afaa84e4ec8e0f70dac77f8b83932a4697e901a2a883f995756061e323ea83ad8dca7cb268b291ff0641e2719cdc311
 SHA512 
cae2f99cc1e914e518a430651b8ba1edf93428f0fb9cde51ec8908435a130f06b5ed91ebc1d875bd424848fa48c6f9e91e6c555c318a8de957a3723d8dcdc61d
+DIST firefox-75.0-bn.xpi 631540 BLAKE2B 
49484c26f55e726dc59e7ea7d767f11638503bfe91838dd637286fce8abd3bc2c1f7da6f6461fbc2a0d389ab57cd2305b93fc39391279f9f149423087f954e86
 SHA512 
6ca86acf1decd45fe760a4335020a9263ca110abc9c694bc89f1cd07a97fa2d32d09b82cf0e6ede6dfafcc060eb4d2a300e54e2ff6d3a02f8a29758573b3a505
+DIST firefox-75.0-br.xpi 546450 BLAKE2B 
fcc4f03305cceea336096f6dd609da53de4107a63ada2d269201114d1d7e2b559c0ba1f0b0e954dfdfc270770d0384daf6742f3307bfea3bb085c44afa4fe2e5
 SHA512 
250ea81da4e3053a197a9eb38ee8097a31fa04106c50863eed41e894efc9301dbf38d3285fe76e896100bfffbefb87febbc8dfa7a4123c10ee36f22461cd57f6
+DIST firefox-75.0-bs.xpi 512938 BLAKE2B 
a2334e4657711fe58eba5cb6ef3c114937f6f1d315a36a44aef2902fe507468674ede5037f2e4493d01c9a1846b98e3b94a2d2b963e599640f38095d7951b4c6
 SHA512 
b793dc65eef4ee8c0fcac1fd1026b91ea428cc080b0fb580d86879b5dec2e4d709c84a3c6c3143ad88b4d5ee018006aaa5192aa9146b6799f0fabbfe4e451b2b
+DIST firefox-75.0-ca.xpi 548046 BLAKE2B 
ae30ed37ce027151f12d6359883402b7b482c293943bce0de0172622bc4a2f36b9d589ac1a7f193853403d067a9f910ffc7b2c586a48a83533c70e3e7666c752
 SHA512 
add3edd4cfa5b45bb0e4ce2b274d2f198aa420ac2b1ac1fedc2d0b1142e0911bdb992bd5b14973a7f33a225f32c6e2c162e0d842f238256a320ea260ab1cabf8
+DIST 

[gentoo-commits] proj/catalyst:master commit in: livecd/cdtar/

2020-04-07 Thread Matt Turner
commit: 8f7800f7a45e4b622ea7262a43d351bf296d47d1
Author: Matt Turner  gentoo  org>
AuthorDate: Wed Apr  8 01:44:03 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Wed Apr  8 01:46:37 2020 +
URL:https://gitweb.gentoo.org/proj/catalyst.git/commit/?id=8f7800f7

cdtar: Delete isolinux-3.72-cdtar.tar.bz2

Has not been used by a spec in releng.git since fbc0ef631bde
(tools-uclibc: remove ancient livecd stuff) in 2014.

Signed-off-by: Matt Turner  gentoo.org>

 livecd/cdtar/isolinux-3.72-cdtar.tar.bz2 | Bin 0 -> 0 bytes
 1 file changed, 0 insertions(+), 0 deletions(-)

diff --git a/livecd/cdtar/isolinux-3.72-cdtar.tar.bz2 
b/livecd/cdtar/isolinux-3.72-cdtar.tar.bz2
deleted file mode 100644
index ceb9bd8b..
Binary files a/livecd/cdtar/isolinux-3.72-cdtar.tar.bz2 and /dev/null differ



[gentoo-commits] proj/catalyst:master commit in: livecd/cdtar/

2020-04-07 Thread Matt Turner
commit: b5606521cd22617e3ac90d53f85447911b58e51b
Author: Matt Turner  gentoo  org>
AuthorDate: Wed Apr  8 01:43:38 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Wed Apr  8 01:46:37 2020 +
URL:https://gitweb.gentoo.org/proj/catalyst.git/commit/?id=b5606521

cdtar: Delete isolinux-3.72-memtest86+-cdtar.tar.bz2

Never referenced by any spec in releng.git.

Signed-off-by: Matt Turner  gentoo.org>

 livecd/cdtar/isolinux-3.72-memtest86+-cdtar.tar.bz2 | Bin 65919 -> 0 bytes
 1 file changed, 0 insertions(+), 0 deletions(-)

diff --git a/livecd/cdtar/isolinux-3.72-memtest86+-cdtar.tar.bz2 
b/livecd/cdtar/isolinux-3.72-memtest86+-cdtar.tar.bz2
deleted file mode 100644
index 8df43494..
Binary files a/livecd/cdtar/isolinux-3.72-memtest86+-cdtar.tar.bz2 and 
/dev/null differ



[gentoo-commits] proj/catalyst:master commit in: livecd/cdtar/

2020-04-07 Thread Matt Turner
commit: ce10264ad74e9950cf6ac3fae03bfd5926fbb42b
Author: Matt Turner  gentoo  org>
AuthorDate: Wed Apr  8 01:39:01 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Wed Apr  8 01:46:37 2020 +
URL:https://gitweb.gentoo.org/proj/catalyst.git/commit/?id=ce10264a

cdtar: Delete grub-memtest86+-cdtar.tar.bz2

Has not been used by a spec in releng.git since 2fa463cb9d76 (Switch
from grub back to isolinux.) in 2008.

Signed-off-by: Matt Turner  gentoo.org>

 livecd/cdtar/grub-memtest86+-cdtar.tar.bz2 | Bin 109665 -> 0 bytes
 1 file changed, 0 insertions(+), 0 deletions(-)

diff --git a/livecd/cdtar/grub-memtest86+-cdtar.tar.bz2 
b/livecd/cdtar/grub-memtest86+-cdtar.tar.bz2
deleted file mode 100644
index e5736ccb..
Binary files a/livecd/cdtar/grub-memtest86+-cdtar.tar.bz2 and /dev/null differ



[gentoo-commits] repo/gentoo:master commit in: dev-util/shellcheck-bin/

2020-04-07 Thread Georgy Yakovlev
commit: fba8457413b63bb552ce4f15497cb8557158f784
Author: Georgy Yakovlev  gentoo  org>
AuthorDate: Wed Apr  8 01:00:15 2020 +
Commit: Georgy Yakovlev  gentoo  org>
CommitDate: Wed Apr  8 01:04:27 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=fba84574

dev-util/shellcheck-bin: bump to 0.7.1

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Georgy Yakovlev  gentoo.org>

 dev-util/shellcheck-bin/Manifest   |  3 +++
 .../shellcheck-bin/shellcheck-bin-0.7.1.ebuild | 30 ++
 2 files changed, 33 insertions(+)

diff --git a/dev-util/shellcheck-bin/Manifest b/dev-util/shellcheck-bin/Manifest
index 9efe5e4d475..2d85f7031e7 100644
--- a/dev-util/shellcheck-bin/Manifest
+++ b/dev-util/shellcheck-bin/Manifest
@@ -1,3 +1,6 @@
 DIST shellcheck-v0.7.0.linux.aarch64.tar.xz 1401444 BLAKE2B 
6e99ece01b0d5f8de482fd9cd53649d7b2df3c2bac2abfd174a765f8666d9cfcff59fb257a2030424abd716b52c63ccb9d2a9fa195e5da572eb15acf78a4bbe6
 SHA512 
9501dc7ee2b4e3b3bd8c4972be6687b72d97ae34f0be35b8721707ebbd21af011b32241fa133868f190ba3fceb5d1cbc9ca06b5634c57d767d7efd520136d200
 DIST shellcheck-v0.7.0.linux.armv6hf.tar.xz 2502980 BLAKE2B 
5e8281a9a8bd7105bb852f917cb2fb252b7d5abdda26da8fc8a5d9aca2a3543fcaf88707ae3aae277578a4fcf973d66e1d457c1769ca4838e3131a1928b56437
 SHA512 
3cb41d339b0da7790b8451b9fb8c6e6d52444ab0f3115871049dbe04968ce88868b305d2be267af627991949f346ee1a8eb95dce4cb0e46c81a24b01d4f18f74
 DIST shellcheck-v0.7.0.linux.x86_64.tar.xz 1545588 BLAKE2B 
30f4cfacdf9024a4f4c8233842f40a6027069e81cf5529f2441b22856773abcd716ee92d2303ad3cda5eaeecac3161e5980c0eedeb4ffa077d5c15c7f356512e
 SHA512 
84e06bee3c8b8c25f46906350fb32708f4b661636c04e55bd19cdd1071265112d84906055372149678d37f09a1667019488c62a0561b81fe6a6b45ad4fae4ac0
+DIST shellcheck-v0.7.1.linux.aarch64.tar.xz 1432492 BLAKE2B 
55bc9f0fc2c3afa598fcbe4bdf7502532fb61084a60e236b8ed8352cca7f3e3842c79b77e8d651ad235def9ae64fc290c926a6a80ce4aa7110abcbd0ba298137
 SHA512 
0068c11477aa7166d0940934ad0e8e243788e1626f080cd57974b03bc4c75581918e50341364e02d0e69ebb21c8c0d063e729ddc7db0a8d0543e7a0188781b6e
+DIST shellcheck-v0.7.1.linux.armv6hf.tar.xz 2527604 BLAKE2B 
a65f837c8370530691eda1c0bbae8b45620f0da8a6ae8dc0200d8b26369584cce18fb4ab4033ea4cda56b5b6f422db20936ccde053a2bdac06a2cd2e52afacdf
 SHA512 
7d8fd04a7b3b7291b3f6236ad15ee1d06a893b7e878b944e22dad1c16d627b583d72d489cccbdfbb4915f85d456e3c72a39ec83c98e31a901c104c8f59f59bf7
+DIST shellcheck-v0.7.1.linux.x86_64.tar.xz 1443836 BLAKE2B 
dce108606eaca97b720c90efb6070d571b95c7f8ece02cde00fd991566135bb10daa6b1190bc04d92eb37ea6af60e55615c3198c7cc7d6bf89b411e877c83df1
 SHA512 
beca3d7819a6bdcfbd044576df4fc284053b48f468b2f03428fe66f4ceb2c05d9b5411357fa15003cb0311406c255084cf7283a3b8fce644c340c2f6aa910b9f

diff --git a/dev-util/shellcheck-bin/shellcheck-bin-0.7.1.ebuild 
b/dev-util/shellcheck-bin/shellcheck-bin-0.7.1.ebuild
new file mode 100644
index 000..22c17699866
--- /dev/null
+++ b/dev-util/shellcheck-bin/shellcheck-bin-0.7.1.ebuild
@@ -0,0 +1,30 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+MY_PN=${PN/-bin/}
+BASE_URI="https://github.com/koalaman/${MY_PN}/releases/download/v${PV}/${MY_PN}-v${PV}.linux;
+
+DESCRIPTION="Shell script analysis tool (binary package)"
+HOMEPAGE="https://www.shellcheck.net/;
+SRC_URI="
+   amd64? ( "${BASE_URI}".x86_64.tar.xz  )
+   arm?   ( "${BASE_URI}".armv6hf.tar.xz )
+   arm64? ( "${BASE_URI}".aarch64.tar.xz )
+"
+
+LICENSE="GPL-3+"
+SLOT="0"
+KEYWORDS="~amd64 ~arm ~arm64"
+
+DEPEND="!dev-util/shellcheck"
+RDEPEND="${DEPEND}"
+
+QA_PREBUILT="/usr/bin/shellcheck"
+S="${WORKDIR}/${MY_PN}-v${PV}"
+
+src_install() {
+   dobin shellcheck
+   einstalldocs
+}



[gentoo-commits] proj/catalyst:master commit in: targets/stage1/

2020-04-07 Thread Matt Turner
commit: 3e49cf88bc4e8fdf96e29af901fabacd6e973fe7
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 22:53:38 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 22:57:58 2020 +
URL:https://gitweb.gentoo.org/proj/catalyst.git/commit/?id=3e49cf88

targets: Use ${clst_root_path} instead of hardcoding it

Signed-off-by: Matt Turner  gentoo.org>

 targets/stage1/chroot.sh | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/targets/stage1/chroot.sh b/targets/stage1/chroot.sh
index 0caf49ee..d409de39 100755
--- a/targets/stage1/chroot.sh
+++ b/targets/stage1/chroot.sh
@@ -49,7 +49,7 @@ fi
 
 # Clear USE
 [ -e ${clst_make_conf} ] && ${clst_sed} -i -e "/^USE=\"${BINDIST} ${USE}\"/d" 
${clst_make_conf}
-make_destpath /tmp/stage1root
+make_destpath "${clst_root_path}"
 
 ## START BUILD
 # First, we drop in a known-good baselayout



[gentoo-commits] proj/catalyst:master commit in: targets/stage1/, targets/stage3/, targets/support/, targets/stage2/

2020-04-07 Thread Matt Turner
commit: 5fb710093c0d4643b981db7763f7f14d04e02d79
Author: Matt Turner  gentoo  org>
AuthorDate: Fri Mar 27 23:34:19 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 23:23:07 2020 +
URL:https://gitweb.gentoo.org/proj/catalyst.git/commit/?id=5fb71009

targets: Reduce locales to C.UTF8 in stage builds

By default, glibc generates around 500 locales with more added each
year.

With USE=-compile-locales, glibc generates the locale archive in
pkg_postinst(). Since files generated in pkg_postinst() are not recorded
in the vdb, this has the advantage of allowing users to freely change
the set of enabled locales (by editing /etc/locale.gen and running
locale-gen).

Since it is so easy for the user to generate any locales they want with
locale-gen (and they probably would have anyway to rid themselves of the
499 locales they don't want!), just disable all locales except for
C.UTF8 and save stage builders a lot of time.

The patch works by
(1) Writing /etc/locale.gen with "C.UTF8 UTF-8"
(2) Setting CONFIG_PROTECT so glibc doesn't overwrite
/etc/locale.gen
(3) Running etc-update to reset /etc/locale.gen

In order to do this I modified scripts/bootstrap.sh in commit
0aa49828ae25 (scripts/bootstrap.sh: Allow CONFIG_PROTECT).

Reducing the set of locales cuts the user time (as reported by time(1))
of the stage2 and stage3 builds as well as the file size of the
resulting xz'd tarballs:

stage 2   stage 3
 size time size  time
before89M   22m42s 206M 45m5s
 after77M4m29s 195M 26m8s

An alternative solution would be to set USE=compiled-locales for glibc,
but that has the downside of being non-default and likely causing users
to unnecessarily rebuild glibc. (We'll do this for the ISOs where we
want all the locales)

Note that this patch does not change the contents of /etc/locale.gen in
the stage3 tarball.

Closes: https://bugs.gentoo.org/686862
Signed-off-by: Matt Turner  gentoo.org>

 targets/stage1/chroot.sh| 1 +
 targets/stage2/chroot.sh| 6 ++
 targets/stage3/chroot.sh| 7 +++
 targets/support/chroot-functions.sh | 6 +-
 4 files changed, 19 insertions(+), 1 deletion(-)

diff --git a/targets/stage1/chroot.sh b/targets/stage1/chroot.sh
index 60e32c60..6e20027a 100755
--- a/targets/stage1/chroot.sh
+++ b/targets/stage1/chroot.sh
@@ -57,6 +57,7 @@ make_destpath "${clst_root_path}"
 run_merge "--oneshot --nodeps sys-apps/baselayout"
 ${clst_sed} -i "/USE=\"${USE} -build\"/d" ${clst_make_conf}
 
+echo "$locales" > /etc/locale.gen
 for etc in /etc "${clst_root_path}"/etc; do
echo "LANG=C.UTF8" > ${etc}/env.d/02locale
 done

diff --git a/targets/stage2/chroot.sh b/targets/stage2/chroot.sh
index 5fac858f..bf98d328 100755
--- a/targets/stage2/chroot.sh
+++ b/targets/stage2/chroot.sh
@@ -4,6 +4,12 @@ source /tmp/chroot-functions.sh
 
 # Setup the environment
 export FEATURES="${clst_myfeatures} nodoc noman noinfo -news"
+export CONFIG_PROTECT="-* /etc/locale.gen"
+
+echo "$locales" > /etc/locale.gen
 
 ## START BUILD
 ${clst_repo_basedir}/${clst_repo_name}/scripts/bootstrap.sh ${bootstrap_opts} 
|| exit 1
+
+# Replace modified /etc/locale.gen with default
+etc-update --automode -5

diff --git a/targets/stage3/chroot.sh b/targets/stage3/chroot.sh
index 4f8bb0ee..e6712015 100755
--- a/targets/stage3/chroot.sh
+++ b/targets/stage3/chroot.sh
@@ -5,4 +5,11 @@ source /tmp/chroot-functions.sh
 ## START BUILD
 setup_pkgmgr
 
+export CONFIG_PROTECT="-* /etc/locale.gen"
+
+echo "$locales" > /etc/locale.gen
+
 run_merge "-e --update --deep --with-bdeps=y @system"
+
+# Replace modified /etc/locale.gen with default
+etc-update --automode -5

diff --git a/targets/support/chroot-functions.sh 
b/targets/support/chroot-functions.sh
index 147ca329..2c256f06 100755
--- a/targets/support/chroot-functions.sh
+++ b/targets/support/chroot-functions.sh
@@ -286,7 +286,7 @@ run_merge() {
export CLEAN_DELAY=0
export EBEEP_IGNORE=0
export EPAUSE_IGNORE=0
-   export CONFIG_PROTECT="-*"
+   [[ $CONFIG_PROTECT != "-*"* ]] && export CONFIG_PROTECT="-*"
 
if [[ "${clst_VERBOSE}" == "true" ]]
then
@@ -433,5 +433,9 @@ Comment=This is a link to the local copy of the Gentoo 
Linux Handbook.
 Icon=text-editor" > /usr/share/applications/gentoo-handbook.desktop
 }
 
+readonly locales="
+C.UTF8 UTF-8
+"
+
 # We do this everywhere, so why not put it in this script
 run_default_funcs



[gentoo-commits] proj/catalyst:master commit in: targets/stage1/

2020-04-07 Thread Matt Turner
commit: f0e772bd3905d02d691d0e41b3a8e3bd3c10e2fe
Author: Matt Turner  gentoo  org>
AuthorDate: Fri Mar 27 23:28:11 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 23:23:07 2020 +
URL:https://gitweb.gentoo.org/proj/catalyst.git/commit/?id=f0e772bd

targets: Set LANG=C.UTF8

Stable glibc now always provides a UTF-8 capable locale, which many
packages require. Set this as the default LANG.

Running locale-gen in stage1 should also solve bug #536938.

Bug: https://bugs.gentoo.org/536938
Bug: https://bugs.gentoo.org/710762
Bug: https://bugs.gentoo.org/714906
Signed-off-by: Matt Turner  gentoo.org>

 targets/stage1/chroot.sh | 12 
 1 file changed, 12 insertions(+)

diff --git a/targets/stage1/chroot.sh b/targets/stage1/chroot.sh
index d409de39..60e32c60 100755
--- a/targets/stage1/chroot.sh
+++ b/targets/stage1/chroot.sh
@@ -57,6 +57,11 @@ make_destpath "${clst_root_path}"
 run_merge "--oneshot --nodeps sys-apps/baselayout"
 ${clst_sed} -i "/USE=\"${USE} -build\"/d" ${clst_make_conf}
 
+for etc in /etc "${clst_root_path}"/etc; do
+   echo "LANG=C.UTF8" > ${etc}/env.d/02locale
+done
+update_env_settings
+
 # Now, we install our packages
 if [ -e ${clst_make_conf} ]; then
echo "CATALYST_USE=\"-* build ${BINDIST} ${clst_CATALYST_USE}\"" >> 
${clst_make_conf}
@@ -71,6 +76,13 @@ fi
 
 run_merge "--oneshot ${clst_buildpkgs}"
 
+# TODO: Drop this when locale-gen in stable glibc supports ROOT.
+#
+# locale-gen does not support the ROOT variable, and as such glibc simply does
+# not run locale-gen when ROOT is set. Since we've set LANG, we need to run
+# locale-gen explicitly.
+locale-gen --destdir "${clst_root_path}"/ || die "locale-gen failed"
+
 # Why are we removing these? Don't we need them for final make.conf?
 for useexpand in ${clst_HOSTUSEEXPAND}; do
x="clst_${useexpand}"



[gentoo-commits] repo/proj/guru:dev commit in: dev-vcs/lazygit/files/, dev-vcs/lazygit/

2020-04-07 Thread Sergey Torokhov
commit: 80233e4bed50a9aa42f502659b5f228027cc1337
Author: Sergey Torokhov  yandex  ru>
AuthorDate: Wed Apr  8 00:21:17 2020 +
Commit: Sergey Torokhov  yandex  ru>
CommitDate: Wed Apr  8 00:21:17 2020 +
URL:https://gitweb.gentoo.org/repo/proj/guru.git/commit/?id=80233e4b

dev-vcs/lazygit: add new package

Add ebuild for lazygit-0.19:
a simple terminal UI for git commands, written in Go with the gocui library.

The patch fix crash if git config use 'showSignature = true' option.

Signed-off-by: Sergey Torokhov  yandex.ru>

 dev-vcs/lazygit/Manifest   |  1 +
 .../lazygit-0.19-fix-gpg-breaking-terminal.patch   | 32 +
 dev-vcs/lazygit/lazygit-0.19.ebuild| 40 ++
 dev-vcs/lazygit/metadata.xml   | 14 
 4 files changed, 87 insertions(+)

diff --git a/dev-vcs/lazygit/Manifest b/dev-vcs/lazygit/Manifest
new file mode 100644
index 000..780c69f
--- /dev/null
+++ b/dev-vcs/lazygit/Manifest
@@ -0,0 +1 @@
+DIST lazygit-0.19.tar.gz 9193308 BLAKE2B 
c07141661387094651cb6137579dea8ab5231b3e08b0733124cc97f1392251db592e01d60297356c8c5df1f1db554bc8a3be86cd07beed158d33b9eabdb015d4
 SHA512 
6259fdb98ae74ee59f395bd79fcbe3280b679883cbc0c190e64a36464c258597e18a6b70842cb242696536cfea35ea9c83f43b05ad20ead4f5120e436875abad

diff --git a/dev-vcs/lazygit/files/lazygit-0.19-fix-gpg-breaking-terminal.patch 
b/dev-vcs/lazygit/files/lazygit-0.19-fix-gpg-breaking-terminal.patch
new file mode 100644
index 000..a3bee2b
--- /dev/null
+++ b/dev-vcs/lazygit/files/lazygit-0.19-fix-gpg-breaking-terminal.patch
@@ -0,0 +1,32 @@
+From 7b7f7f0696d94c01852290fa3552caffa0b2af7b Mon Sep 17 00:00:00 2001
+From: Glenn Vriesman 
+Date: Mon, 6 Apr 2020 19:26:12 +0200
+Subject: [PATCH] fix: fixed gpg breaking terminal
+
+Signed-off-by: Glenn Vriesman 
+---
+ pkg/commands/commit_list_builder.go | 11 ++-
+ 1 file changed, 6 insertions(+), 5 deletions(-)
+
+diff --git 
a/src/github.com/jesseduffield/lazygit/pkg/commands/commit_list_builder.go 
b/pkg/commands/commit_list_builder.go
+index 1204b488..f4bbc9dd 100644
+--- a/src/github.com/jesseduffield/lazygit/pkg/commands/commit_list_builder.go
 b/src/github.com/jesseduffield/lazygit/pkg/commands/commit_list_builder.go
+@@ -109,11 +109,12 @@ func (c *CommitListBuilder) GetCommits(options 
GetCommitsOptions) ([]*Commit, er
+   cmd := c.getLogCmd(options)
+ 
+   err = RunLineOutputCmd(cmd, func(line string) (bool, error) {
+-  commit := c.extractCommitFromLine(line)
+-  _, unpushed := unpushedCommits[commit.ShortSha()]
+-  commit.Status = map[bool]string{true: "unpushed", false: 
"pushed"}[unpushed]
+-  commits = append(commits, commit)
+-
++  if strings.Split(line, " ")[0] != "gpg:" {
++  commit := c.extractCommitFromLine(line)
++  _, unpushed := unpushedCommits[commit.ShortSha()]
++  commit.Status = map[bool]string{true: "unpushed", 
false: "pushed"}[unpushed]
++  commits = append(commits, commit)
++  }
+   return false, nil
+   })
+   if err != nil {

diff --git a/dev-vcs/lazygit/lazygit-0.19.ebuild 
b/dev-vcs/lazygit/lazygit-0.19.ebuild
new file mode 100644
index 000..6181240
--- /dev/null
+++ b/dev-vcs/lazygit/lazygit-0.19.ebuild
@@ -0,0 +1,40 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+EGO_PN="github.com/jesseduffield/lazygit"
+
+inherit golang-build golang-vcs-snapshot
+
+DESCRIPTION="Lazygit, a simple terminal UI for git commands"
+HOMEPAGE="https://github.com/jesseduffield/lazygit;
+SRC_URI="https://github.com/jesseduffield/${PN}/archive/v${PV}.tar.gz -> 
${P}.tar.gz"
+
+LICENSE="MIT"
+SLOT="0"
+KEYWORDS="~amd64"
+IUSE=""
+
+DEPEND=( sys-libs/glibc )
+RDEPEND=(
+   ${DEPEND}
+   dev-vcs/git
+)
+
+PATCHES=( "${FILESDIR}/${P}-fix-gpg-breaking-terminal.patch" )
+
+src_compile() {
+   GOPATH="${S}" go build -v -o bin/lazygit src/${EGO_PN}/main.go || die
+}
+
+src_install() {
+   dobin bin/lazygit
+
+   local DOCS=(
+   src/${EGO_PN}/{CONTRIBUTING,README}.md
+   src/${EGO_PN}/docs/*.md
+   src/${EGO_PN}/docs/keybindings/*.md
+   )
+   einstalldocs
+}

diff --git a/dev-vcs/lazygit/metadata.xml b/dev-vcs/lazygit/metadata.xml
new file mode 100644
index 000..dceadcf
--- /dev/null
+++ b/dev-vcs/lazygit/metadata.xml
@@ -0,0 +1,14 @@
+
+http://www.gentoo.org/dtd/metadata.dtd;>
+
+   
+   torokhov-...@yandex.ru
+   Sergey Torokhov
+   
+
+   A simple terminal UI for git commands, written in Go with the gocui 
library
+
+
+   jesseduffield/lazygit
+
+



[gentoo-commits] repo/gentoo:master commit in: sys-kernel/genkernel/

2020-04-07 Thread Thomas Deutschmann
commit: 1b4957a329487b8155f2a44be2feb985d5f81bef
Author: Thomas Deutschmann  gentoo  org>
AuthorDate: Tue Apr  7 23:23:28 2020 +
Commit: Thomas Deutschmann  gentoo  org>
CommitDate: Tue Apr  7 23:24:49 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=1b4957a3

sys-kernel/genkernel: update live ebuild

- Bump btrfs-progs to v5.6

- Bump cryptsetup to v2.3.1

- Bump LVM2 to v2.02.187

- Bump XFSPROGS to v5.5.0

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Thomas Deutschmann  gentoo.org>

 sys-kernel/genkernel/Manifest  |  5 +
 sys-kernel/genkernel/genkernel-.ebuild | 10 +-
 2 files changed, 10 insertions(+), 5 deletions(-)

diff --git a/sys-kernel/genkernel/Manifest b/sys-kernel/genkernel/Manifest
index c079bc430a0..c36d460ef1a 100644
--- a/sys-kernel/genkernel/Manifest
+++ b/sys-kernel/genkernel/Manifest
@@ -1,14 +1,18 @@
 DIST LVM2.2.02.173.tgz 2363504 BLAKE2B 
a516bc9b68b7b7529f4436d8849ca741eb3ca1b5ac2eb2fb2915507935bdd28b5e234e74c1bce827e5761f57b5936510d08107e0dc1c320190f952c706f128d3
 SHA512 
c2ea8beafe006abf9282f51ec98600fd0ebff816d53c10ecbb19bbf336ada4825135cf9c92ccd364afb18f8b1d7e163eff5bdec8dfdd70dfb9ba45db2f6bdd5e
 DIST LVM2.2.02.186.tgz 2389759 BLAKE2B 
e094c0135d455386ea5789208899d4dbdd5e78bebf52e49ab5587f881fbc2b94c6accecacf1b4ed182b0c87046402c00a47a1b724795a94fe3ec998b580a77ae
 SHA512 
06a1c00142ee41d8a576a5e06a5beae70baced3020e753ce3b612355cc4d9e33be4acf58569d49436c4ee1118d288d884c7301b7d886074eaf9f2fa6b0248c03
+DIST LVM2.2.02.187.tgz 2405544 BLAKE2B 
be804be3c64927a8848e8ea8de228fb563b6f8c22628b785aabb33fc993629e5370788216bd814246aeb3a5546fd5446383ce24342e716579887556edf2bbed2
 SHA512 
3ce56f0c0d2e7dbcdae5be263199f73ee5c4c052599d53cde9b16500a326d0340893344f4671839be06b5b4225d592175d01c9974db14f2dc220d6e9a1d47e91
 DIST boost_1_72_0.tar.bz2 106907358 BLAKE2B 
ab270a0e3cb24da687d86785e2d2e6d7731b4dbc07bd839eadb642dfa5a428ad584acb1f3529661a8de9a986008ff3427491041059ea2b742348d02e00761cd8
 SHA512 
63bbd1743e7c904b2e69fdc2eafd1c2a8a30fd70d960dcd366059d0100f000cb605d56cbd9397bb18421631f1c9552a772c434d0f0caddbe56302273f51fd1f6
 DIST btrfs-progs-v5.4.1.tar.xz 2107476 BLAKE2B 
1ea58f49b0f8185e944010804e544643a2eafeea58fecb480b13095c362350c218f0602fbb43a96705a81befe88ec3e3abe35cc90d4732006479b059aa7fed32
 SHA512 
56381b37036aecea61b758fb4971abfeda24a387bb3a828f7d54eb068982a37763a8ebe2bcc6be61d6a8bc2057dddcd4754325b236e14d8ec02e58cf711f192f
+DIST btrfs-progs-v5.6.tar.xz 2114336 BLAKE2B 
24c0a2ae17bdfa7075c026427ddc3945533a8a3f2608f339b5560e91b71b23d754e2c9ae7d847b21bb73ce0894cf21ccef441fbfb28cfe40a9ce316664102f57
 SHA512 
4eb39da2a583fc2dfa2f5f161a44c1f107dc6ad1e789a8746cb89eecdd288718e279041bebcb85473da4780eecb8e4c297d2b0163262a941cf88b99c07951cc4
 DIST busybox-1.27.2.tar.bz2 2216527 BLAKE2B 
77b8fa325b9ba691c0ac944537efdf5d87011b1a87c1c244588136f78055be9f2a71c77eea5edf1d20cfe50e59b15527511b14160930c946ed4e82c9608cb991
 SHA512 
d99e86b652562ebe1a5d50e1ba3877a1d1612997c17cb8d8e4212da181211a9b741a881cb051f14cb3ee8aea40226cf2cde80a076baed265d3bc0a4e96a5031c
 DIST busybox-1.31.1.tar.bz2 2430221 BLAKE2B 
95c2345bc715eb7a1f08816a40add9b7a6176ef509a84069343ec2caddec58d8d57a07676ca2b03c209734169321433e27ba963b4c8b98dbfda4e409dcc347b4
 SHA512 
0d1197c25d963d7f95ef21e08c06c0d6124ac7b59c99989e891f744ffee4878a3b1fe44a247241a9da39fa5de0ba87f1b6d862401b591f277e66e89c02764bbf
 DIST coreutils-8.32.tar.xz 5547836 BLAKE2B 
0ad99c176c19ec214fcfd0845523e5362f0151827707c759bd46c0fe8d2501c6ad1c29c5b71266f6525857bc0d56c472db0d7fe29953b6c65e2e6c76bdf3c515
 SHA512 
1c8f3584efd61b4b02e7ac5db8e103b63cfb2063432caaf1e64cb2dcc56d8c657d1133bbf10bd41468d6a1f31142e6caa81d16ae68fa3e6e84075c253613a145
 DIST cryptsetup-2.3.0.tar.xz 11035660 BLAKE2B 
0fff903cdb07d91183bbd35afb660aad42d31188a80d0ef6294c40082b39fdcde25da4fe1bf679ebe308133fc63051876ce813a2ef3a557f63b574d6f6f49d8c
 SHA512 
d4af8edb7a50603028c6c6999ae7a1851d2232ee11d4a501270afb424f0a7dc82893a6a5d30d3a3188634aa80ec1a79f22a91b539910df10d07f8d9ae532cb08
+DIST cryptsetup-2.3.1.tar.xz 11041592 BLAKE2B 
acf3bb17503575b5d7edb58d0ab13989a2bc70ec96583dfc057b8258fd98a39a088411a9e0175d51d816b9164e5ec193710f1ada92427b1e6c6a53c5b8a6b9ea
 SHA512 
e6ee77d72eda0b990db894d794a686f22043161b17b5f5c8cd54a64c5751f884a241c76b03bbccd52f74440c609036d50ed8503584bc3a0a011e4854a60dd4bf
 DIST dmraid-1.0.0.rc16-3.tar.bz2 232743 BLAKE2B 
290c5bb7f1b12ac48627d8afcc346327b2fcce31b1015d5974c956d94f607b297e383158cd8741f03a770cdeb3f42c3e6341ebfcbc2220e122d89c2603eee512
 SHA512 
7c45e5117adc52fc2094b1b2bad4f4c518a46317a2196611966d72085ba3587c4ac8d1080f9d934888c01788f2b2d3d621c6f0d3e2a023c0fb1f9f3fa7fc127e
 DIST dropbear-2019.78.tar.bz2 2708659 BLAKE2B 
212b173cfea8655b43a8d93422dd4d3e0d669a67681cb17d6494b6083e6e4c58d21d52850c0cdf414617ee3dcaa071e376d0b5b156b6856cee2e4fe111550f7d
 SHA512 
f667ba8dae17ea89c118642b566f2c134c71bfd0b8bacea5cf7ec87d75ac79bd7cd1864a8788367a89d30ee35427d389ef6416375adff6e83caae30ff3e0549f
 DIST 

[gentoo-commits] proj/genkernel:master commit in: patches/e2fsprogs/1.45.5/, patches/e2fsprogs/1.45.6/

2020-04-07 Thread Thomas Deutschmann
commit: d959fcac98cca72892f71e9225e64425ede41519
Author: Thomas Deutschmann  gentoo  org>
AuthorDate: Tue Apr  7 23:21:11 2020 +
Commit: Thomas Deutschmann  gentoo  org>
CommitDate: Tue Apr  7 23:21:11 2020 +
URL:https://gitweb.gentoo.org/proj/genkernel.git/commit/?id=d959fcac

e2fsprogs bumped to v1.45.6

Signed-off-by: Thomas Deutschmann  gentoo.org>

 .../e2fsprogs/{1.45.5 => 1.45.6}/e2fsprogs-1.42.13-fix-build-cflags.patch | 0
 .../e2fsprogs/{1.45.5 => 1.45.6}/e2fsprogs-1.44.6-parallel_install.patch  | 0
 2 files changed, 0 insertions(+), 0 deletions(-)

diff --git a/patches/e2fsprogs/1.45.5/e2fsprogs-1.42.13-fix-build-cflags.patch 
b/patches/e2fsprogs/1.45.6/e2fsprogs-1.42.13-fix-build-cflags.patch
similarity index 100%
rename from patches/e2fsprogs/1.45.5/e2fsprogs-1.42.13-fix-build-cflags.patch
rename to patches/e2fsprogs/1.45.6/e2fsprogs-1.42.13-fix-build-cflags.patch

diff --git a/patches/e2fsprogs/1.45.5/e2fsprogs-1.44.6-parallel_install.patch 
b/patches/e2fsprogs/1.45.6/e2fsprogs-1.44.6-parallel_install.patch
similarity index 100%
rename from patches/e2fsprogs/1.45.5/e2fsprogs-1.44.6-parallel_install.patch
rename to patches/e2fsprogs/1.45.6/e2fsprogs-1.44.6-parallel_install.patch



[gentoo-commits] proj/genkernel:master commit in: patches/btrfs-progs/5.6/, patches/btrfs-progs/5.4.1/

2020-04-07 Thread Thomas Deutschmann
commit: 9ccd2b181aeabaad4c132db41f639c1024be7a42
Author: Thomas Deutschmann  gentoo  org>
AuthorDate: Tue Apr  7 23:20:43 2020 +
Commit: Thomas Deutschmann  gentoo  org>
CommitDate: Tue Apr  7 23:20:43 2020 +
URL:https://gitweb.gentoo.org/proj/genkernel.git/commit/?id=9ccd2b18

btrfs-progs bumped to v5.6

Signed-off-by: Thomas Deutschmann  gentoo.org>

 patches/btrfs-progs/{5.4.1 => 5.6}/btrfs-lzo2.patch | 0
 patches/btrfs-progs/{5.4.1 => 5.6}/btrfs-m4.patch   | 0
 2 files changed, 0 insertions(+), 0 deletions(-)

diff --git a/patches/btrfs-progs/5.4.1/btrfs-lzo2.patch 
b/patches/btrfs-progs/5.6/btrfs-lzo2.patch
similarity index 100%
rename from patches/btrfs-progs/5.4.1/btrfs-lzo2.patch
rename to patches/btrfs-progs/5.6/btrfs-lzo2.patch

diff --git a/patches/btrfs-progs/5.4.1/btrfs-m4.patch 
b/patches/btrfs-progs/5.6/btrfs-m4.patch
similarity index 100%
rename from patches/btrfs-progs/5.4.1/btrfs-m4.patch
rename to patches/btrfs-progs/5.6/btrfs-m4.patch



[gentoo-commits] proj/genkernel:master commit in: patches/lvm/2.02.187/, patches/lvm/2.02.186/

2020-04-07 Thread Thomas Deutschmann
commit: f3cc1245dd113d4ad931c5f42ecd5b39925d2d7f
Author: Thomas Deutschmann  gentoo  org>
AuthorDate: Tue Apr  7 22:42:55 2020 +
Commit: Thomas Deutschmann  gentoo  org>
CommitDate: Tue Apr  7 22:42:55 2020 +
URL:https://gitweb.gentoo.org/proj/genkernel.git/commit/?id=f3cc1245

Bump LVM2 to v2.02.187

Signed-off-by: Thomas Deutschmann  gentoo.org>

 patches/lvm/{2.02.186 => 2.02.187}/lvm2-001-example.conf.in.patch | 0
 .../lvm/{2.02.186 => 2.02.187}/lvm2-002-always-make-static-libdm.patch| 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-003-lvm2create_initrd.patch   | 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-004-createinitrd.patch| 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-005-locale-muck.patch | 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-006-asneeded.patch| 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-007-dynamic-static-ldflags.patch  | 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-008-static-pkgconfig-libs.patch   | 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-009-pthread-pkgconfig.patch   | 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-010-static-libm.patch | 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-011-HPPA-no-O_DIRECT.patch| 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-012-mallinfo.patch| 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-013-fix-stdio-usage.patch | 0
 .../lvm2-014-make-malloc-realloc-check-optional.patch | 0
 patches/lvm/{2.02.186 => 2.02.187}/lvm2-015-mksh_build.patch  | 0
 15 files changed, 0 insertions(+), 0 deletions(-)

diff --git a/patches/lvm/2.02.186/lvm2-001-example.conf.in.patch 
b/patches/lvm/2.02.187/lvm2-001-example.conf.in.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-001-example.conf.in.patch
rename to patches/lvm/2.02.187/lvm2-001-example.conf.in.patch

diff --git a/patches/lvm/2.02.186/lvm2-002-always-make-static-libdm.patch 
b/patches/lvm/2.02.187/lvm2-002-always-make-static-libdm.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-002-always-make-static-libdm.patch
rename to patches/lvm/2.02.187/lvm2-002-always-make-static-libdm.patch

diff --git a/patches/lvm/2.02.186/lvm2-003-lvm2create_initrd.patch 
b/patches/lvm/2.02.187/lvm2-003-lvm2create_initrd.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-003-lvm2create_initrd.patch
rename to patches/lvm/2.02.187/lvm2-003-lvm2create_initrd.patch

diff --git a/patches/lvm/2.02.186/lvm2-004-createinitrd.patch 
b/patches/lvm/2.02.187/lvm2-004-createinitrd.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-004-createinitrd.patch
rename to patches/lvm/2.02.187/lvm2-004-createinitrd.patch

diff --git a/patches/lvm/2.02.186/lvm2-005-locale-muck.patch 
b/patches/lvm/2.02.187/lvm2-005-locale-muck.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-005-locale-muck.patch
rename to patches/lvm/2.02.187/lvm2-005-locale-muck.patch

diff --git a/patches/lvm/2.02.186/lvm2-006-asneeded.patch 
b/patches/lvm/2.02.187/lvm2-006-asneeded.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-006-asneeded.patch
rename to patches/lvm/2.02.187/lvm2-006-asneeded.patch

diff --git a/patches/lvm/2.02.186/lvm2-007-dynamic-static-ldflags.patch 
b/patches/lvm/2.02.187/lvm2-007-dynamic-static-ldflags.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-007-dynamic-static-ldflags.patch
rename to patches/lvm/2.02.187/lvm2-007-dynamic-static-ldflags.patch

diff --git a/patches/lvm/2.02.186/lvm2-008-static-pkgconfig-libs.patch 
b/patches/lvm/2.02.187/lvm2-008-static-pkgconfig-libs.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-008-static-pkgconfig-libs.patch
rename to patches/lvm/2.02.187/lvm2-008-static-pkgconfig-libs.patch

diff --git a/patches/lvm/2.02.186/lvm2-009-pthread-pkgconfig.patch 
b/patches/lvm/2.02.187/lvm2-009-pthread-pkgconfig.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-009-pthread-pkgconfig.patch
rename to patches/lvm/2.02.187/lvm2-009-pthread-pkgconfig.patch

diff --git a/patches/lvm/2.02.186/lvm2-010-static-libm.patch 
b/patches/lvm/2.02.187/lvm2-010-static-libm.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-010-static-libm.patch
rename to patches/lvm/2.02.187/lvm2-010-static-libm.patch

diff --git a/patches/lvm/2.02.186/lvm2-011-HPPA-no-O_DIRECT.patch 
b/patches/lvm/2.02.187/lvm2-011-HPPA-no-O_DIRECT.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-011-HPPA-no-O_DIRECT.patch
rename to patches/lvm/2.02.187/lvm2-011-HPPA-no-O_DIRECT.patch

diff --git a/patches/lvm/2.02.186/lvm2-012-mallinfo.patch 
b/patches/lvm/2.02.187/lvm2-012-mallinfo.patch
similarity index 100%
rename from patches/lvm/2.02.186/lvm2-012-mallinfo.patch
rename to patches/lvm/2.02.187/lvm2-012-mallinfo.patch

diff --git a/patches/lvm/2.02.186/lvm2-013-fix-stdio-usage.patch 
b/patches/lvm/2.02.187/lvm2-013-fix-stdio-usage.patch
similarity index 100%

[gentoo-commits] proj/genkernel:master commit in: gkbuilds/

2020-04-07 Thread Thomas Deutschmann
commit: 8d3182553b151bcaf9010fae4dcc091f18096839
Author: Thomas Deutschmann  gentoo  org>
AuthorDate: Tue Apr  7 22:39:11 2020 +
Commit: Thomas Deutschmann  gentoo  org>
CommitDate: Tue Apr  7 22:39:11 2020 +
URL:https://gitweb.gentoo.org/proj/genkernel.git/commit/?id=8d318255

gkbuilds/lvm: Force CONFIG_SHELL=bash

Bug: https://bugs.gentoo.org/716496
Signed-off-by: Thomas Deutschmann  gentoo.org>

 gkbuilds/lvm.gkbuild | 3 +++
 1 file changed, 3 insertions(+)

diff --git a/gkbuilds/lvm.gkbuild b/gkbuilds/lvm.gkbuild
index 9cedead..3af06e6 100644
--- a/gkbuilds/lvm.gkbuild
+++ b/gkbuilds/lvm.gkbuild
@@ -34,6 +34,9 @@ src_configure() {
myconf+=( --with-cache-${texec}=/usr/sbin/cache_${texec} )
done
 
+   # Hard-wire this to bash as some shells (dash) don't know
+   # "-o pipefail" #682404, #716496
+   CONFIG_SHELL="/bin/bash" \
gkconf "${myconf[@]}"
 }
 



[gentoo-commits] proj/genkernel:master commit in: /

2020-04-07 Thread Thomas Deutschmann
commit: c0e013c9770eca18ea6fc68c87709d6fc6b1dc41
Author: Thomas Deutschmann  gentoo  org>
AuthorDate: Tue Apr  7 22:56:13 2020 +
Commit: Thomas Deutschmann  gentoo  org>
CommitDate: Tue Apr  7 22:59:57 2020 +
URL:https://gitweb.gentoo.org/proj/genkernel.git/commit/?id=c0e013c9

gen_determineargs.sh: determine_real_args(): Error out early when already 
running within a sandbox

We cannot spawn a sandbox when we are already running within a sandbox.
This commit will make genkernel error out early to tell user about
the problem.

Signed-off-by: Thomas Deutschmann  gentoo.org>

 gen_determineargs.sh | 5 +
 1 file changed, 5 insertions(+)

diff --git a/gen_determineargs.sh b/gen_determineargs.sh
index 6c5d01c..95ec402 100755
--- a/gen_determineargs.sh
+++ b/gen_determineargs.sh
@@ -1012,6 +1012,11 @@ determine_real_args() {
SANDBOX_COMMAND=
if isTrue "${SANDBOX}"
then
+   if [ ${SANDBOX_ON} -eq 1 ]
+   then
+   gen_die "SANDBOX_ON=1 detected -- You cannot 
use --sandbox when already running within a sandbox!"
+   fi
+
SANDBOX_COMMAND="$(which sandbox 2>/dev/null)"
if [ -z "${SANDBOX_COMMAND}" ]
then



[gentoo-commits] repo/gentoo:master commit in: games-action/minetest/

2020-04-07 Thread James Le Cuirot
commit: 1f6c5053bd2d0768ac4a4e8929f12e8065fb61a6
Author: William Breathitt Gray  gmail  com>
AuthorDate: Sun Apr  5 20:07:54 2020 +
Commit: James Le Cuirot  gentoo  org>
CommitDate: Tue Apr  7 22:49:19 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=1f6c5053

games-action/minetest: Version bump to 5.2.0

Closes: https://bugs.gentoo.org/716366
Signed-off-by: William Breathitt Gray  gmail.com>
Closes: https://github.com/gentoo/gentoo/pull/15240
Signed-off-by: James Le Cuirot  gentoo.org>

 games-action/minetest/Manifest  |   1 +
 games-action/minetest/minetest-5.2.0.ebuild | 135 
 2 files changed, 136 insertions(+)

diff --git a/games-action/minetest/Manifest b/games-action/minetest/Manifest
index c808144d7b0..15e396dfe92 100644
--- a/games-action/minetest/Manifest
+++ b/games-action/minetest/Manifest
@@ -1 +1,2 @@
 DIST minetest-5.1.1.tar.gz 9002025 BLAKE2B 
8258850a0f45125a09e0a4cf5eda7a8860be4f0a5e564767952e27fc8509593bf0615c1457a0ee168f6eeedcf1065e288b787d74e1d0a2180870bc1bae818bfc
 SHA512 
4a36a86a3e5f8f5246ff3410e9ab182631f38292bea077e7dbc25fdc1520e5a479ffbd5ec447000fb4999ab252a59bf976299e6fecda1f8cd47f40549885766b
+DIST minetest-5.2.0.tar.gz 10361815 BLAKE2B 
244cacc92f08f571f45bedef9a8f2154a8105fc83c1396d626e78dcb0d4050c3ba9610ccf2ec2864a5d4b73d9d31aac0dc162fdcc277ef35cc1ead53158cc51f
 SHA512 
47e3cdf488d50ea61659ac3b72960c9971270d1a793e0d79dcb649c89f7a6e65a16c21e1b903d08c916a2ebcbd3fd2164ec67173a3d4f2a2e9bb3a6351b48851

diff --git a/games-action/minetest/minetest-5.2.0.ebuild 
b/games-action/minetest/minetest-5.2.0.ebuild
new file mode 100644
index 000..73950475263
--- /dev/null
+++ b/games-action/minetest/minetest-5.2.0.ebuild
@@ -0,0 +1,135 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit cmake xdg
+
+DESCRIPTION="A free open-source voxel game engine with easy modding and game 
creation"
+HOMEPAGE="https://www.minetest.net;
+SRC_URI="https://github.com/${PN}/${PN}/archive/${PV}.tar.gz -> ${P}.tar.gz"
+
+LICENSE="LGPL-2.1+ CC-BY-SA-3.0 OFL-1.1 Apache-2.0"
+SLOT="0"
+KEYWORDS="~amd64 ~x86"
+IUSE="+client +curl doc +leveldb ncurses nls postgres redis +server +sound 
spatial +truetype"
+REQUIRED_USE="|| ( client server )"
+
+RDEPEND="
+   dev-db/sqlite:3
+   dev-lang/luajit:2
+   dev-libs/gmp:0=
+   dev-libs/jsoncpp:=
+   sys-libs/zlib
+   client? (
+   app-arch/bzip2
+   dev-games/irrlicht
+   media-libs/libpng:0=
+   virtual/jpeg:0
+   virtual/opengl
+   x11-libs/libX11
+   x11-libs/libXxf86vm
+   sound? (
+   media-libs/libogg
+   media-libs/libvorbis
+   media-libs/openal
+   )
+   truetype? ( media-libs/freetype:2 )
+   )
+   curl? ( net-misc/curl )
+   leveldb? ( dev-libs/leveldb:= )
+   ncurses? ( sys-libs/ncurses:0= )
+   nls? ( virtual/libintl )
+   postgres? ( >=dev-db/postgresql-9.5:= )
+   redis? ( dev-libs/hiredis:= )
+   server? (
+   acct-group/minetest
+   acct-user/minetest
+   dev-games/irrlicht-headers
+   )
+   spatial? ( sci-libs/libspatialindex:= )"
+DEPEND="${RDEPEND}"
+BDEPEND="
+   doc? (
+   app-doc/doxygen
+   media-gfx/graphviz
+   )
+   nls? ( sys-devel/gettext )"
+
+src_prepare() {
+   cmake_src_prepare
+   # set paths
+   sed \
+   -e "s#@BINDIR@#${EPREFIX}/usr/bin#g" \
+   -e "s#@GROUP@#${PN}#g" \
+   "${FILESDIR}"/minetestserver.confd > 
"${T}"/minetestserver.confd || die
+
+   # remove bundled libraries
+   rm -rf lib || die
+}
+
+src_configure() {
+   local mycmakeargs=(
+   -DBUILD_CLIENT=$(usex client)
+   -DBUILD_SERVER=$(usex server)
+   -DCUSTOM_BINDIR="${EPREFIX}/usr/bin"
+   -DCUSTOM_DOCDIR="${EPREFIX}/usr/share/doc/${PF}"
+   -DCUSTOM_EXAMPLE_CONF_DIR="${EPREFIX}/usr/share/doc/${PF}"
+   -DCUSTOM_LOCALEDIR="${EPREFIX}/usr/share/${PN}/locale"
+   -DCUSTOM_SHAREDIR="${EPREFIX}/usr/share/${PN}"
+   -DENABLE_CURL=$(usex curl)
+   -DENABLE_CURSES=$(usex ncurses)
+   -DENABLE_FREETYPE=$(usex truetype)
+   -DENABLE_GETTEXT=$(usex nls)
+   -DENABLE_GLES=0
+   -DENABLE_LEVELDB=$(usex leveldb)
+   -DENABLE_LUAJIT=1
+   -DENABLE_POSTGRESQL=$(usex postgres)
+   -DENABLE_REDIS=$(usex redis)
+   -DENABLE_SPATIAL=$(usex spatial)
+   -DENABLE_SOUND=$(usex sound)
+   -DENABLE_SYSTEM_GMP=1
+   -DENABLE_SYSTEM_JSONCPP=1
+   -DRUN_IN_PLACE=0
+   )
+
+   cmake_src_configure
+}
+

[gentoo-commits] repo/gentoo:master commit in: games-action/minetest/

2020-04-07 Thread James Le Cuirot
commit: c18e58a368dff2f761db9ec4be9f11425411fdbc
Author: James Le Cuirot  gentoo  org>
AuthorDate: Tue Apr  7 22:50:53 2020 +
Commit: James Le Cuirot  gentoo  org>
CommitDate: Tue Apr  7 22:50:53 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=c18e58a3

games-action/minetest: Drop old 5.1.1

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: James Le Cuirot  gentoo.org>

 games-action/minetest/Manifest  |   1 -
 games-action/minetest/minetest-5.1.1.ebuild | 139 
 2 files changed, 140 deletions(-)

diff --git a/games-action/minetest/Manifest b/games-action/minetest/Manifest
index 15e396dfe92..ea2ab27923e 100644
--- a/games-action/minetest/Manifest
+++ b/games-action/minetest/Manifest
@@ -1,2 +1 @@
-DIST minetest-5.1.1.tar.gz 9002025 BLAKE2B 
8258850a0f45125a09e0a4cf5eda7a8860be4f0a5e564767952e27fc8509593bf0615c1457a0ee168f6eeedcf1065e288b787d74e1d0a2180870bc1bae818bfc
 SHA512 
4a36a86a3e5f8f5246ff3410e9ab182631f38292bea077e7dbc25fdc1520e5a479ffbd5ec447000fb4999ab252a59bf976299e6fecda1f8cd47f40549885766b
 DIST minetest-5.2.0.tar.gz 10361815 BLAKE2B 
244cacc92f08f571f45bedef9a8f2154a8105fc83c1396d626e78dcb0d4050c3ba9610ccf2ec2864a5d4b73d9d31aac0dc162fdcc277ef35cc1ead53158cc51f
 SHA512 
47e3cdf488d50ea61659ac3b72960c9971270d1a793e0d79dcb649c89f7a6e65a16c21e1b903d08c916a2ebcbd3fd2164ec67173a3d4f2a2e9bb3a6351b48851

diff --git a/games-action/minetest/minetest-5.1.1.ebuild 
b/games-action/minetest/minetest-5.1.1.ebuild
deleted file mode 100644
index 66f7329bb98..000
--- a/games-action/minetest/minetest-5.1.1.ebuild
+++ /dev/null
@@ -1,139 +0,0 @@
-# Copyright 1999-2020 Gentoo Authors
-# Distributed under the terms of the GNU General Public License v2
-
-EAPI=7
-
-inherit cmake xdg
-
-DESCRIPTION="A free open-source voxel game engine with easy modding and game 
creation"
-HOMEPAGE="https://www.minetest.net;
-SRC_URI="https://github.com/${PN}/${PN}/archive/${PV}.tar.gz -> ${P}.tar.gz"
-
-LICENSE="LGPL-2.1+ CC-BY-SA-3.0 OFL-1.1 Apache-2.0"
-SLOT="0"
-KEYWORDS="~amd64 ~x86"
-IUSE="+client +curl doc +leveldb ncurses nls postgres redis +server +sound 
spatial +truetype"
-REQUIRED_USE="|| ( client server )"
-
-RDEPEND="
-   dev-db/sqlite:3
-   dev-lang/luajit:2
-   dev-libs/gmp:0=
-   dev-libs/jsoncpp:=
-   sys-libs/zlib
-   client? (
-   app-arch/bzip2
-   dev-games/irrlicht
-   media-libs/libpng:0=
-   virtual/jpeg:0
-   virtual/opengl
-   x11-libs/libX11
-   x11-libs/libXxf86vm
-   sound? (
-   media-libs/libogg
-   media-libs/libvorbis
-   media-libs/openal
-   )
-   truetype? ( media-libs/freetype:2 )
-   )
-   curl? ( net-misc/curl )
-   leveldb? ( dev-libs/leveldb:= )
-   ncurses? ( sys-libs/ncurses:0= )
-   nls? ( virtual/libintl )
-   postgres? ( >=dev-db/postgresql-9.5:= )
-   redis? ( dev-libs/hiredis:= )
-   server? (
-   acct-group/minetest
-   acct-user/minetest
-   dev-games/irrlicht-headers
-   )
-   spatial? ( sci-libs/libspatialindex:= )"
-DEPEND="${RDEPEND}"
-BDEPEND="
-   doc? (
-   app-doc/doxygen
-   media-gfx/graphviz
-   )
-   nls? ( sys-devel/gettext )"
-
-src_prepare() {
-   cmake_src_prepare
-   # set paths
-   sed \
-   -e "s#@BINDIR@#${EPREFIX}/usr/bin#g" \
-   -e "s#@GROUP@#${PN}#g" \
-   "${FILESDIR}"/minetestserver.confd > 
"${T}"/minetestserver.confd || die
-
-   # remove bundled libraries
-   rm -rf lib || die
-}
-
-src_configure() {
-   local mycmakeargs=(
-   -DBUILD_CLIENT=$(usex client)
-   -DBUILD_SERVER=$(usex server)
-   -DCUSTOM_BINDIR="${EPREFIX}/usr/bin"
-   -DCUSTOM_DOCDIR="${EPREFIX}/usr/share/doc/${PF}"
-   -DCUSTOM_EXAMPLE_CONF_DIR="${EPREFIX}/usr/share/doc/${PF}"
-   -DCUSTOM_LOCALEDIR="${EPREFIX}/usr/share/${PN}/locale"
-   -DCUSTOM_SHAREDIR="${EPREFIX}/usr/share/${PN}"
-   -DENABLE_CURL=$(usex curl)
-   -DENABLE_CURSES=$(usex ncurses)
-   -DENABLE_FREETYPE=$(usex truetype)
-   -DENABLE_GETTEXT=$(usex nls)
-   -DENABLE_GLES=0
-   -DENABLE_LEVELDB=$(usex leveldb)
-   -DENABLE_LUAJIT=1
-   -DENABLE_POSTGRESQL=$(usex postgres)
-   -DENABLE_REDIS=$(usex redis)
-   -DENABLE_SPATIAL=$(usex spatial)
-   -DENABLE_SOUND=$(usex sound)
-   -DENABLE_SYSTEM_GMP=1
-   -DENABLE_SYSTEM_JSONCPP=1
-   -DRUN_IN_PLACE=0
-   )
-
-   use server && mycmakeargs+=(
-   -DIRRLICHT_INCLUDE_DIR="${EPREFIX}/usr/include/irrlicht"
-   )
-
-   

[gentoo-commits] repo/gentoo:master commit in: profiles/arch/mips/

2020-04-07 Thread Matt Turner
commit: b68d0f5531a9e05e9404a00730c7e97cbf20e231
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 22:25:47 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 22:25:47 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=b68d0f55

profiles/mips: Drop elogind mask

Signed-off-by: Matt Turner  gentoo.org>

 profiles/arch/mips/use.mask | 4 
 1 file changed, 4 deletions(-)

diff --git a/profiles/arch/mips/use.mask b/profiles/arch/mips/use.mask
index 32ba177b1fe..78794268b67 100644
--- a/profiles/arch/mips/use.mask
+++ b/profiles/arch/mips/use.mask
@@ -4,10 +4,6 @@
 # Unmask the flag which corresponds to ARCH.
 -mips
 
-# Andreas Sturmlechner  (2019-03-31)
-# sys-auth/elogind is not yet keyworded here. bug #681200
-elogind
-
 # Matt Turner  (2018-03-25)
 # Unmask systemd since it is keyworded here.
 -systemd



[gentoo-commits] repo/gentoo:master commit in: profiles/arch/s390/

2020-04-07 Thread Matt Turner
commit: a726d83a99e31af3f46328d78fdf9e5c928c9860
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 22:26:04 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 22:26:04 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=a726d83a

profiles/s390: Drop elogind mask

Signed-off-by: Matt Turner  gentoo.org>

 profiles/arch/s390/use.mask | 4 
 1 file changed, 4 deletions(-)

diff --git a/profiles/arch/s390/use.mask b/profiles/arch/s390/use.mask
index bf02b596a3c..53b5ce2ca11 100644
--- a/profiles/arch/s390/use.mask
+++ b/profiles/arch/s390/use.mask
@@ -15,10 +15,6 @@ libglvnd
 # Dependencies not keyworded.
 ayatana
 
-# Andreas Sturmlechner  (2019-03-31)
-# sys-auth/elogind is not yet keyworded here. bug #681200
-elogind
-
 # Michał Górny  (2018-07-16)
 # Python 3.7 support requires fresh versions of packages which are stuck
 # at keywordreqs.



[gentoo-commits] repo/gentoo:master commit in: sys-auth/elogind/

2020-04-07 Thread Matt Turner
commit: 56998f9d10d70c32f50963aa7c1625159feb7c49
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 22:25:04 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 22:25:04 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=56998f9d

sys-auth/elogind-243.7: add ~s390, bug 681200

Signed-off-by: Matt Turner  gentoo.org>

 sys-auth/elogind/elogind-243.7.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/sys-auth/elogind/elogind-243.7.ebuild 
b/sys-auth/elogind/elogind-243.7.ebuild
index d8f6b12129c..9a2819e1b70 100644
--- a/sys-auth/elogind/elogind-243.7.ebuild
+++ b/sys-auth/elogind/elogind-243.7.ebuild
@@ -9,7 +9,7 @@ if [[ ${PV} = ** ]]; then
inherit git-r3
 else
SRC_URI="https://github.com/${PN}/${PN}/archive/v${PV}.tar.gz -> 
${P}.tar.gz"
-   KEYWORDS="~alpha ~amd64 ~arm ~arm64 ~hppa ~ia64 ~mips ~ppc ~ppc64 
~sparc ~x86"
+   KEYWORDS="~alpha ~amd64 ~arm ~arm64 ~hppa ~ia64 ~mips ~ppc ~ppc64 ~s390 
~sparc ~x86"
 fi
 
 inherit linux-info meson pam udev xdg-utils



[gentoo-commits] repo/gentoo:master commit in: sys-auth/elogind/

2020-04-07 Thread Matt Turner
commit: a9821cadeab0e89dc4fc7ae98396cf26ffd7bad8
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 22:25:02 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 22:25:02 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=a9821cad

sys-auth/elogind-243.7: add ~mips, bug 681200

Signed-off-by: Matt Turner  gentoo.org>

 sys-auth/elogind/elogind-243.7.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/sys-auth/elogind/elogind-243.7.ebuild 
b/sys-auth/elogind/elogind-243.7.ebuild
index ec495cedb70..d8f6b12129c 100644
--- a/sys-auth/elogind/elogind-243.7.ebuild
+++ b/sys-auth/elogind/elogind-243.7.ebuild
@@ -9,7 +9,7 @@ if [[ ${PV} = ** ]]; then
inherit git-r3
 else
SRC_URI="https://github.com/${PN}/${PN}/archive/v${PV}.tar.gz -> 
${P}.tar.gz"
-   KEYWORDS="~alpha ~amd64 ~arm ~arm64 ~hppa ~ia64 ~ppc ~ppc64 ~sparc ~x86"
+   KEYWORDS="~alpha ~amd64 ~arm ~arm64 ~hppa ~ia64 ~mips ~ppc ~ppc64 
~sparc ~x86"
 fi
 
 inherit linux-info meson pam udev xdg-utils



[gentoo-commits] repo/gentoo:master commit in: sys-fs/mtools/

2020-04-07 Thread Matt Turner
commit: e0dd64617ba3f84d35e724dbd619ebb02bace608
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 20:56:36 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 22:11:07 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=e0dd6461

sys-fs/mtools: add ~ia64

Signed-off-by: Matt Turner  gentoo.org>

 sys-fs/mtools/mtools-4.0.24.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/sys-fs/mtools/mtools-4.0.24.ebuild 
b/sys-fs/mtools/mtools-4.0.24.ebuild
index 2ba65b9a407..a10154dee9b 100644
--- a/sys-fs/mtools/mtools-4.0.24.ebuild
+++ b/sys-fs/mtools/mtools-4.0.24.ebuild
@@ -11,7 +11,7 @@ SRC_URI="mirror://gnu/${PN}/${P}.tar.bz2"
 
 LICENSE="GPL-3"
 SLOT="0"
-KEYWORDS="~alpha ~amd64 ~arm ~hppa ~ppc ~ppc64 ~sparc ~x86 ~x64-macos 
~x64-solaris"
+KEYWORDS="~alpha ~amd64 ~arm ~hppa ~ia64 ~ppc ~ppc64 ~sparc ~x86 ~x64-macos 
~x64-solaris"
 IUSE="X elibc_glibc"
 
 RDEPEND="



[gentoo-commits] repo/gentoo:master commit in: dev-lang/crystal/

2020-04-07 Thread Sergei Trofimovich
commit: eabfcfdf339fb9fcb50e1fda56cc29cad4b8b03e
Author: Sergei Trofimovich  gentoo  org>
AuthorDate: Tue Apr  7 21:58:13 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 21:58:13 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=eabfcfdf

dev-lang/crystal: use llvm-9, llvm-10 breaks crystal.

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Sergei Trofimovich  gentoo.org>

 dev-lang/crystal/crystal-0.34.0.ebuild | 4 +++-
 1 file changed, 3 insertions(+), 1 deletion(-)

diff --git a/dev-lang/crystal/crystal-0.34.0.ebuild 
b/dev-lang/crystal/crystal-0.34.0.ebuild
index 65305e025a7..fa18cc6204d 100644
--- a/dev-lang/crystal/crystal-0.34.0.ebuild
+++ b/dev-lang/crystal/crystal-0.34.0.ebuild
@@ -22,7 +22,9 @@ IUSE="doc debug examples blocking-stdio-hack +xml +yaml"
 
 RESTRICT=test # not stable for day-to-day runs
 
-LLVM_MAX_SLOT=10
+# On llvm-10 target crashes using USE=-debug codegen.
+# Might be just non-deterministic.
+LLVM_MAX_SLOT=9
 
 # dev-libs/boehm-gc[static-libs] dependency problem,  check the issue: 
https://github.com/manastech/crystal/issues/1382
 DEPEND="



[gentoo-commits] repo/gentoo:master commit in: dev-db/libdbi-drivers/

2020-04-07 Thread Sergei Trofimovich
commit: 818f7056e5cc46a83b6bcd7a7b6c9c52b020a1ee
Author: Rolf Eike Beer  sf-mail  de>
AuthorDate: Tue Apr  7 21:41:24 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 21:48:04 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=818f7056

dev-db/libdbi-drivers: drop 0.9.0 to ~sparc

virtual/mysql is ~sparc.

Signed-off-by: Rolf Eike Beer  sf-mail.de>
Signed-off-by: Sergei Trofimovich  gentoo.org>

 dev-db/libdbi-drivers/libdbi-drivers-0.9.0.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/dev-db/libdbi-drivers/libdbi-drivers-0.9.0.ebuild 
b/dev-db/libdbi-drivers/libdbi-drivers-0.9.0.ebuild
index f19914603b5..9a087d0524c 100644
--- a/dev-db/libdbi-drivers/libdbi-drivers-0.9.0.ebuild
+++ b/dev-db/libdbi-drivers/libdbi-drivers-0.9.0.ebuild
@@ -11,7 +11,7 @@ HOMEPAGE="http://libdbi-drivers.sourceforge.net/;
 LICENSE="LGPL-2.1"
 
 IUSE="doc firebird mysql oci8 postgres +sqlite static-libs"
-KEYWORDS="~alpha amd64 arm arm64 hppa ~ia64 ~m68k ~mips ppc ppc64 s390 sparc 
x86"
+KEYWORDS="~alpha amd64 arm arm64 hppa ~ia64 ~m68k ~mips ppc ppc64 s390 ~sparc 
x86"
 SLOT=0
 REQUIRED_USE="|| ( mysql postgres sqlite firebird oci8 )"
 RESTRICT="firebird? ( bindist )"



[gentoo-commits] repo/gentoo:master commit in: dev-lang/crystal/files/, dev-lang/crystal/

2020-04-07 Thread Sergei Trofimovich
commit: e638e3d755bdd6c83363824ee282295cf28cb644
Author: Sergei Trofimovich  gentoo  org>
AuthorDate: Tue Apr  7 21:46:43 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 21:47:20 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=e638e3d7

dev-lang/crystal: bump up to 0.34.0

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Sergei Trofimovich  gentoo.org>

 dev-lang/crystal/Manifest  |   3 +
 dev-lang/crystal/crystal-0.34.0.ebuild | 121 +
 .../crystal/files/crystal-0.34.0-no-usr-lib.patch  |  14 +++
 3 files changed, 138 insertions(+)

diff --git a/dev-lang/crystal/Manifest b/dev-lang/crystal/Manifest
index f2003bb9de6..d0d69e11e9a 100644
--- a/dev-lang/crystal/Manifest
+++ b/dev-lang/crystal/Manifest
@@ -4,3 +4,6 @@ DIST crystal-0.32.1.tar.gz 2225383 BLAKE2B 
81cdda508945ebea481c3ad784ecdccffe25e
 DIST crystal-0.33.0-1-linux-i686.tar.gz 29627750 BLAKE2B 
284c300eb57e9192c367b1692c95a8da584820ecd068515cf59174106bdcd4341033e68ecdcc64a263dcf1c69ca58f9403e9b4b8e166c86b1b6747e4e0d2ea92
 SHA512 
8ff06e5782a84575ddc8210f92bc6d5702692e2674be4fcef470dfeff3ec325954eb665b222cb3f332e335cae4ae49cc06ffe4ce939519d0947225b452b4
 DIST crystal-0.33.0-1-linux-x86_64.tar.gz 27553242 BLAKE2B 
c24ab3e1577c33de9e9de2fa03f0fe831821b70b72ee9fb421eab9aed8b0ba357547160be9fff20c30b2d52e6c6d75bbde19dc322638c5c3f33ba2aa14dbf4c4
 SHA512 
7c815335ff882effd9dfc22cbeec6cee6e014805bf048bedf4476b1ecdf3a87bd8d53543c78be3493f937659a88041cd5370814eba043c81f23e7ef707ccd834
 DIST crystal-0.33.0.tar.gz 2242162 BLAKE2B 
0d9dbdd230bb190209772fafaeb1d59008cbe90b0bd33f851886bf90e7ac497c0bcef7609d6295dd4a4bad213fb687dea3d16c42ebe3bc92b3e06df156c53570
 SHA512 
41f518ec5c8f2f2cffb84105e0cc5096d4ba7ef64887ad0089aa37109fa5fa8e28747fe4f4ca8a74012e7b77d8c7a9d72cd9da787a330a4a62b5e55b40f0e57b
+DIST crystal-0.34.0-1-linux-i686.tar.gz 30161592 BLAKE2B 
b53dd3c3fb36ae7654396bcca305dbdd32c90f72e3e549fd054517230df3fdadcc07056d4a53c600e1fbae14ce79b66268191a3a01f27e1d625451865a414774
 SHA512 
47874a6a349dcf42b92532c4d454f8c65f2f94d78240f2a5baa865063ed373410be0ff5e457d4d1c3483ce8965e894fa918973fa03ee934f226a56a8a544f8d0
+DIST crystal-0.34.0-1-linux-x86_64.tar.gz 28036344 BLAKE2B 
dbd9305cadfda3a9d072672c91a0a7e9b230507d69c84735af900c40e602dbd6777b48ddce679935b87cff669d0534a8d65b09dc0fa6d8167f66117ba8468f8a
 SHA512 
291713acb6291c106e60c2b7bcdab33a6df3d6f464c81392ea340b25d01d301c743c0d81f29eb9b32a2099203775a8fc2df9617f90c28699e4864bee16f4252e
+DIST crystal-0.34.0.tar.gz 2270363 BLAKE2B 
bef2f09ef45ed9c7c9ffc5bcc9e8d6516c799b60ae3d87d5512fcd36634231091c1c534a708059362c3e5bc9db36a377dffd2dbca4290964362ea8740345e4f2
 SHA512 
6167ca5974d02167fe695cc51fe8ef95e56076a2af88eae39a12b07930b96ca0b30d53fd7c6e2296139d89a1c7eacfce5326f25a8fa3487cdb446ab592723f66

diff --git a/dev-lang/crystal/crystal-0.34.0.ebuild 
b/dev-lang/crystal/crystal-0.34.0.ebuild
new file mode 100644
index 000..65305e025a7
--- /dev/null
+++ b/dev-lang/crystal/crystal-0.34.0.ebuild
@@ -0,0 +1,121 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit bash-completion-r1 llvm multiprocessing toolchain-funcs
+
+BV=${PV}-1
+BV_AMD64=${BV}-linux-x86_64
+BV_X86=${BV}-linux-i686
+
+DESCRIPTION="The Crystal Programming Language"
+HOMEPAGE="https://crystal-lang.org;
+SRC_URI="https://github.com/crystal-lang/crystal/archive/${PV}.tar.gz -> 
${P}.tar.gz
+   amd64? ( 
https://github.com/crystal-lang/crystal/releases/download/${BV/-*}/crystal-${BV_AMD64}.tar.gz
 )
+   x86? ( 
https://github.com/crystal-lang/crystal/releases/download/${BV/-*}/crystal-${BV_X86}.tar.gz
 )"
+
+LICENSE="Apache-2.0"
+SLOT="0"
+KEYWORDS="~amd64"
+IUSE="doc debug examples blocking-stdio-hack +xml +yaml"
+
+RESTRICT=test # not stable for day-to-day runs
+
+LLVM_MAX_SLOT=10
+
+# dev-libs/boehm-gc[static-libs] dependency problem,  check the issue: 
https://github.com/manastech/crystal/issues/1382
+DEPEND="
+   sys-devel/llvm:${LLVM_MAX_SLOT}
+   dev-libs/boehm-gc[static-libs,threads]
+   dev-libs/libatomic_ops
+   dev-libs/libevent
+   dev-libs/libpcre
+   sys-libs/libunwind
+   dev-libs/pcl
+   dev-libs/gmp:0
+"
+RDEPEND="${DEPEND}
+   xml? ( dev-libs/libxml2 )
+   yaml? ( dev-libs/libyaml )
+"
+
+PATCHES=(
+   "${FILESDIR}"/${PN}-0.31.0-verbose.patch
+   "${FILESDIR}"/${PN}-0.26.1-gentoo-tests-sandbox.patch
+   "${FILESDIR}"/${PN}-0.27.0-extra-spec-flags.patch
+   #"${FILESDIR}"/${PN}-0.27.0-max-age-0-test.patch
+   "${FILESDIR}"/${PN}-0.27.0-gentoo-tests-long-unix.patch
+   "${FILESDIR}"/${PN}-0.27.0-gentoo-tests-long-unix-2.patch
+   "${FILESDIR}"/${PN}-0.34.0-no-usr-lib.patch
+)
+
+src_prepare() {
+   default
+
+   use blocking-stdio-hack && eapply 
"${FILESDIR}"/"${PN}"-0.22.0-blocking-stdio-hack.patch
+}
+
+src_compile() {
+   local 

[gentoo-commits] repo/gentoo:master commit in: net-firewall/nftables/files/, net-firewall/nftables/files/man-pages/, ...

2020-04-07 Thread Patrick McLean
commit: 0d207f6f90bfed5e7128ee6502806476023a5c5e
Author: Patrick McLean  gentoo  org>
AuthorDate: Tue Apr  7 21:37:02 2020 +
Commit: Patrick McLean  gentoo  org>
CommitDate: Tue Apr  7 21:37:19 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=0d207f6f

net-firewall/nftables-0.9.4-r2: revbump, cleanup deps, provide man pages

It turns out that flex and bison aren't actually needed to build, but
there was a bug in the build system that made it abort if they weren't
available. Add a patch to fix this bug, and remove the extra deps.

Disable USE=doc by default and provide pre-built man pages in a separate
tarball. Script to build them is at man-pages/gen-manpages.bash

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Patrick McLean  gentoo.org>

 net-firewall/nftables/Manifest |   1 +
 .../nftables/files/man-pages/gen-manpages.bash |  72 ++
 ...w-building-from-tarballs-without-yacc-lex.patch |  37 +
 net-firewall/nftables/nftables-0.9.4-r2.ebuild | 158 +
 4 files changed, 268 insertions(+)

diff --git a/net-firewall/nftables/Manifest b/net-firewall/nftables/Manifest
index 8efe409eb2f..e2877db7245 100644
--- a/net-firewall/nftables/Manifest
+++ b/net-firewall/nftables/Manifest
@@ -1,2 +1,3 @@
 DIST nftables-0.9.3.tar.bz2 786759 BLAKE2B 
578276d861fdb2b843223aca1276bbc1dda9627d0058259a966e324e30ee64d8c102d1e2cceb82d29143caa9dcd1a4492df168f1c87b136fc7b3a1a7dc8568a8
 SHA512 
d264f6fc75c95510e29fe7d5b82ae418d502f40437b098ba6117ffb1374d9989d70a7296e2e58c5fb25142145a987bb9c160902637899f892589809f9541db43
+DIST nftables-0.9.4-manpages.tar.xz 38580 BLAKE2B 
bb561c7824d032ecfff5c98af10c95af6f5188377f43de8398be7e503adff0441d49fa3e2cefcb646927cc1a4222957f0cc75d5ad4c770ef3a3f8cb8a677c5ce
 SHA512 
1b94ff06ceccf75bbefbf64496d5fa0b492907d7ec5fe41f7808c6e239b2a0a42e88d61e35e22485abee7e4bd382178e962a7c5b113433247ca329cbfa408bca
 DIST nftables-0.9.4.tar.bz2 792788 BLAKE2B 
3f2d8ff3bcfe3ab815ee369c4937adef5e5730edee8ea59b32031732802e608bcb47ddd3e55303ad6c295158aff51b2f2c069d98600db83d732ff78836c7abb5
 SHA512 
cef5b5f26f3a2893a3eb1323f1f0ecfd6e2865e0eb040e9b7da5824e5be2274b888e661abe96e828add9e951f47303e30cb7c9238d267a031c0f99b5f3b6e2c0

diff --git a/net-firewall/nftables/files/man-pages/gen-manpages.bash 
b/net-firewall/nftables/files/man-pages/gen-manpages.bash
new file mode 100644
index 000..a2223d3dd5b
--- /dev/null
+++ b/net-firewall/nftables/files/man-pages/gen-manpages.bash
@@ -0,0 +1,72 @@
+#!/bin/bash
+#
+# create manpages for nftables
+
+declare -A MAN_PAGES
+
+MAN_PAGES=(
+   [nft.8]="nft.txt"
+   [libnftables-json.5]="libnftables-json.adoc"
+   [libnftables.3]="libnftables.adoc"
+)
+
+build_manpages() {
+   tar axf "${distfile}" -C "${srcdir}" || return
+
+   pushd "${srcdir}/${version}/doc" > /dev/null || return
+   local manpage
+   for manpage in "${!MAN_PAGES[@]}"; do
+   a2x -L --doctype manpage --format manpage -D . 
"${MAN_PAGES[${manpage}]}" || return
+   done
+   popd > /dev/null || return
+
+   local -a tarfiles
+   readarray -t tarfiles < <(printf -- "${version}/doc/%s\\n" 
"${!MAN_PAGES[@]}")
+
+   tar -Jc --owner='root:0' --group='root:0' \
+   --transform="s:^${version}/doc:${version}-manpages:" \
+   -f "${version}-manpages.tar.xz" \
+   -C "${srcdir}" \
+   "${tarfiles[@]}" || return
+
+   rm -rf "${srcdir:?}/${version}" || return
+}
+
+main() {
+   shopt -s failglob
+   local version="${1}" srcdir="${0%/*}"
+
+   if [[ -z ${version} ]]; then
+   # shellcheck disable=SC2016
+   version=$(
+   find . -maxdepth 1 -type d -a -name 'nftables-*' 
-printf '%P\0' 2>/dev/null \
+   | LC_COLLATE=C sort -z \
+   | sed -z -n '${p;Q}' \
+   | tr -d '\000'
+   )
+   if [[ -z ${version} ]]; then
+   # shellcheck disable=SC2016
+   version=$(
+   find . -maxdepth 3 -mindepth 3 -type f -a -name 
'nftables-*.ebuild' -printf '%P\0' 2>/dev/null \
+   | LC_COLLATE=C sort -z \
+   | sed -r -z -n 
'${s:.*/::;s:-r[0-9]+::;s:[.]ebuild::;p;Q}' \
+   | tr -d '\000'
+   )
+   if [[ -z ${version} ]]; then
+   printf 'Usage %s \n' "${0}" >&2
+   return 1
+   fi
+   fi
+   elif [[ ${version} =~ [0-9.]+ ]]; then
+   version="nftables-${version}"
+   fi
+
+   local distdir distfile
+   local -a distfiles
+   distdir="$(portageq distdir)" || return
+   distfiles=( "${distdir}/${version}.tar."* ) || return
+   distfile="${distfiles[-1]}"
+   

[gentoo-commits] repo/gentoo:master commit in: app-admin/haskell-updater/

2020-04-07 Thread Sergei Trofimovich
commit: 99e89c5fbe94d50ab511178ce2d4177909877cc4
Author: Rolf Eike Beer  sf-mail  de>
AuthorDate: Tue Apr  7 21:30:53 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 21:32:23 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=99e89c5f

app-admin/haskell-updater: drop on sparc, haskell is gone

Signed-off-by: Rolf Eike Beer  sf-mail.de>
Signed-off-by: Sergei Trofimovich  gentoo.org>

 app-admin/haskell-updater/haskell-updater-1.2.10.ebuild| 2 +-
 app-admin/haskell-updater/haskell-updater-1.2.12-r1.ebuild | 2 +-
 app-admin/haskell-updater/haskell-updater-1.2.9.ebuild | 2 +-
 app-admin/haskell-updater/haskell-updater-1.3.1.ebuild | 2 +-
 4 files changed, 4 insertions(+), 4 deletions(-)

diff --git a/app-admin/haskell-updater/haskell-updater-1.2.10.ebuild 
b/app-admin/haskell-updater/haskell-updater-1.2.10.ebuild
index 786f50b68ef..029f62c35c9 100644
--- a/app-admin/haskell-updater/haskell-updater-1.2.10.ebuild
+++ b/app-admin/haskell-updater/haskell-updater-1.2.10.ebuild
@@ -12,7 +12,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="GPL-2"
 SLOT="0"
-KEYWORDS="amd64 ~ia64 ppc ppc64 sparc x86 ~amd64-linux ~ppc-macos ~x64-macos 
~x86-macos ~sparc-solaris ~x86-solaris"
+KEYWORDS="amd64 ~ia64 ppc ppc64 x86 ~amd64-linux ~ppc-macos ~x64-macos 
~x86-macos ~sparc-solaris ~x86-solaris"
 IUSE=""
 
 DEPEND=">=dev-lang/ghc-6.12.1"

diff --git a/app-admin/haskell-updater/haskell-updater-1.2.12-r1.ebuild 
b/app-admin/haskell-updater/haskell-updater-1.2.12-r1.ebuild
index 2cddf4d18ed..8d82089f7c6 100644
--- a/app-admin/haskell-updater/haskell-updater-1.2.12-r1.ebuild
+++ b/app-admin/haskell-updater/haskell-updater-1.2.12-r1.ebuild
@@ -12,7 +12,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="GPL-2"
 SLOT="0"
-KEYWORDS="~amd64 ~ia64 ~ppc ~ppc64 ~sparc ~x86 ~amd64-linux ~ppc-macos 
~x64-macos ~x86-macos ~sparc-solaris ~x86-solaris"
+KEYWORDS="~amd64 ~ia64 ~ppc ~ppc64 ~x86 ~amd64-linux ~ppc-macos ~x64-macos 
~x86-macos ~sparc-solaris ~x86-solaris"
 IUSE=""
 
 DEPEND=">=dev-lang/ghc-6.12.1"

diff --git a/app-admin/haskell-updater/haskell-updater-1.2.9.ebuild 
b/app-admin/haskell-updater/haskell-updater-1.2.9.ebuild
index 786f50b68ef..029f62c35c9 100644
--- a/app-admin/haskell-updater/haskell-updater-1.2.9.ebuild
+++ b/app-admin/haskell-updater/haskell-updater-1.2.9.ebuild
@@ -12,7 +12,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="GPL-2"
 SLOT="0"
-KEYWORDS="amd64 ~ia64 ppc ppc64 sparc x86 ~amd64-linux ~ppc-macos ~x64-macos 
~x86-macos ~sparc-solaris ~x86-solaris"
+KEYWORDS="amd64 ~ia64 ppc ppc64 x86 ~amd64-linux ~ppc-macos ~x64-macos 
~x86-macos ~sparc-solaris ~x86-solaris"
 IUSE=""
 
 DEPEND=">=dev-lang/ghc-6.12.1"

diff --git a/app-admin/haskell-updater/haskell-updater-1.3.1.ebuild 
b/app-admin/haskell-updater/haskell-updater-1.3.1.ebuild
index 286cb86841c..cc4962834c6 100644
--- a/app-admin/haskell-updater/haskell-updater-1.3.1.ebuild
+++ b/app-admin/haskell-updater/haskell-updater-1.3.1.ebuild
@@ -12,7 +12,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="GPL-2"
 SLOT="0"
-KEYWORDS="amd64 ~ia64 ~ppc ~ppc64 ~sparc x86 ~amd64-linux ~x86-linux 
~ppc-macos ~x64-macos ~x86-macos ~sparc-solaris ~x86-solaris"
+KEYWORDS="amd64 ~ia64 ~ppc ~ppc64 x86 ~amd64-linux ~x86-linux ~ppc-macos 
~x64-macos ~x86-macos ~sparc-solaris ~x86-solaris"
 IUSE=""
 
 DEPEND=">=dev-lang/ghc-6.12.1"



[gentoo-commits] repo/gentoo:master commit in: dev-util/bustle/

2020-04-07 Thread Sergei Trofimovich
commit: b7be81807a5c03b270de69665bc919f69e45e91b
Author: Rolf Eike Beer  sf-mail  de>
AuthorDate: Tue Apr  7 21:29:39 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 21:32:23 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=b7be8180

dev-util/bustle: drop sparc, deps don't build at all

Signed-off-by: Rolf Eike Beer  sf-mail.de>
Signed-off-by: Sergei Trofimovich  gentoo.org>

 dev-util/bustle/bustle-0.4.2-r1.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/dev-util/bustle/bustle-0.4.2-r1.ebuild 
b/dev-util/bustle/bustle-0.4.2-r1.ebuild
index 0f634cbe79d..69821eeaea1 100644
--- a/dev-util/bustle/bustle-0.4.2-r1.ebuild
+++ b/dev-util/bustle/bustle-0.4.2-r1.ebuild
@@ -14,7 +14,7 @@ 
SRC_URI="http://willthompson.co.uk/${PN}/releases/${PV}/${P}.tar.gz https://dev.
 
 LICENSE="LGPL-2 GPL-2" # bustle-dbus-monitor.c is GPL-2, rest is LGPL-2
 SLOT="0"
-KEYWORDS="amd64 ~ia64 ppc ppc64 sparc x86"
+KEYWORDS="amd64 ~ia64 ppc ppc64 x86"
 IUSE=""
 
 RDEPEND="dev-libs/glib:2



[gentoo-commits] repo/gentoo:master commit in: dev-vcs/darcs/

2020-04-07 Thread Sergei Trofimovich
commit: af892e93f6a9ffa47be54b7956f45abecdeada6e
Author: Rolf Eike Beer  sf-mail  de>
AuthorDate: Tue Apr  7 20:43:54 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 21:29:54 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=af892e93

dev-vcs/darcs: drop sparc, deps don't build at all

Signed-off-by: Rolf Eike Beer  sf-mail.de>
Signed-off-by: Sergei Trofimovich  gentoo.org>

 dev-vcs/darcs/darcs-2.8.4-r6.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/dev-vcs/darcs/darcs-2.8.4-r6.ebuild 
b/dev-vcs/darcs/darcs-2.8.4-r6.ebuild
index 8e3f284e35b..b77a3146c09 100644
--- a/dev-vcs/darcs/darcs-2.8.4-r6.ebuild
+++ b/dev-vcs/darcs/darcs-2.8.4-r6.ebuild
@@ -14,7 +14,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="GPL-2"
 SLOT="0/${PV}"
-KEYWORDS="amd64 ~ia64 ppc ppc64 sparc x86 ~amd64-linux ~x86-linux ~ppc-macos 
~x86-macos ~x86-solaris"
+KEYWORDS="amd64 ~ia64 ppc ppc64 x86 ~amd64-linux ~x86-linux ~ppc-macos 
~x86-macos ~x86-solaris"
 IUSE="doc test"
 RESTRICT="!test? ( test )"
 



[gentoo-commits] repo/gentoo:master commit in: x11-wm/xmonad/

2020-04-07 Thread Sergei Trofimovich
commit: e5c233b2d0e7384d550658415f89645180676001
Author: Rolf Eike Beer  sf-mail  de>
AuthorDate: Tue Apr  7 20:54:46 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 21:29:54 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=e5c233b2

x11-wm/xmonad: drop sparc, deps don't build at all

Signed-off-by: Rolf Eike Beer  sf-mail.de>
Signed-off-by: Sergei Trofimovich  gentoo.org>

 x11-wm/xmonad/xmonad-0.11-r1.ebuild | 2 +-
 x11-wm/xmonad/xmonad-0.11-r3.ebuild | 2 +-
 x11-wm/xmonad/xmonad-0.11.1.ebuild  | 2 +-
 x11-wm/xmonad/xmonad-0.12.ebuild| 2 +-
 4 files changed, 4 insertions(+), 4 deletions(-)

diff --git a/x11-wm/xmonad/xmonad-0.11-r1.ebuild 
b/x11-wm/xmonad/xmonad-0.11-r1.ebuild
index 0ac630861cc..a45aa0b4aab 100644
--- a/x11-wm/xmonad/xmonad-0.11-r1.ebuild
+++ b/x11-wm/xmonad/xmonad-0.11-r1.ebuild
@@ -14,7 +14,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="BSD"
 SLOT="0/${PV}"
-KEYWORDS="amd64 ~ppc64 ~sparc x86"
+KEYWORDS="amd64 ~ppc64 x86"
 IUSE="+default-term"
 
 RDEPEND="dev-haskell/extensible-exceptions:=[profile?]

diff --git a/x11-wm/xmonad/xmonad-0.11-r3.ebuild 
b/x11-wm/xmonad/xmonad-0.11-r3.ebuild
index 67cb46bdbd7..fbe3e95182a 100644
--- a/x11-wm/xmonad/xmonad-0.11-r3.ebuild
+++ b/x11-wm/xmonad/xmonad-0.11-r3.ebuild
@@ -14,7 +14,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="BSD"
 SLOT="0/${PV}"
-KEYWORDS="~amd64 ~ppc64 ~sparc ~x86"
+KEYWORDS="~amd64 ~ppc64 ~x86"
 IUSE="+default-term no-autorepeat-keys"
 
 RDEPEND="dev-haskell/extensible-exceptions:=[profile?]

diff --git a/x11-wm/xmonad/xmonad-0.11.1.ebuild 
b/x11-wm/xmonad/xmonad-0.11.1.ebuild
index ff10cb0d1e5..588cc05d6bc 100644
--- a/x11-wm/xmonad/xmonad-0.11.1.ebuild
+++ b/x11-wm/xmonad/xmonad-0.11.1.ebuild
@@ -14,7 +14,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="BSD"
 SLOT="0/${PV}"
-KEYWORDS="~amd64 ~ppc64 ~sparc ~x86"
+KEYWORDS="~amd64 ~ppc64 ~x86"
 IUSE="+default-term no-autorepeat-keys"
 
 RDEPEND="dev-haskell/extensible-exceptions:=[profile?]

diff --git a/x11-wm/xmonad/xmonad-0.12.ebuild b/x11-wm/xmonad/xmonad-0.12.ebuild
index 288a2bf6fe8..c9bbcad8c31 100644
--- a/x11-wm/xmonad/xmonad-0.12.ebuild
+++ b/x11-wm/xmonad/xmonad-0.12.ebuild
@@ -15,7 +15,7 @@ SRC_URI="https://hackage.haskell.org/package/${P}/${P}.tar.gz;
 
 LICENSE="BSD"
 SLOT="0/${PV}"
-KEYWORDS="amd64 ~ppc64 ~sparc x86"
+KEYWORDS="amd64 ~ppc64 x86"
 IUSE="+default-term no-autorepeat-keys"
 
 RESTRICT=test # fails test on ghc-8 (assert has different text of exception)



[gentoo-commits] repo/gentoo:master commit in: profiles/arch/sparc/

2020-04-07 Thread Sergei Trofimovich
commit: edcb783caf03f8724dd72959ee681c7a2555851b
Author: Rolf Eike Beer  sf-mail  de>
AuthorDate: Tue Apr  7 20:49:26 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 21:29:53 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=edcb783c

profiles/arch/sparc/package.use.mask: mask layman[darcs]

Signed-off-by: Rolf Eike Beer  sf-mail.de>
Signed-off-by: Sergei Trofimovich  gentoo.org>

 profiles/arch/sparc/package.use.mask | 4 
 1 file changed, 4 insertions(+)

diff --git a/profiles/arch/sparc/package.use.mask 
b/profiles/arch/sparc/package.use.mask
index d5ac6a3d53d..ebe070dcb23 100644
--- a/profiles/arch/sparc/package.use.mask
+++ b/profiles/arch/sparc/package.use.mask
@@ -1,6 +1,10 @@
 # Copyright 1999-2020 Gentoo Authors
 # Distributed under the terms of the GNU General Public License v2
 
+# Rolf Eike Beer  (2020-04-06)
+# ghc does not build, which is needed for darcs, bug #711944
+app-portage/layman darcs
+
 # Rolf Eike Beer  (2020-04-06)
 # grub pc is not supported on sparc
 sys-boot/grub:2 grub_platforms_pc grub_platforms_efi-32 grub_platforms_efi-64 
grub_platforms_xen grub_platforms_xen-pvh



[gentoo-commits] repo/gentoo:master commit in: media-plugins/kodi-vfs-rar/

2020-04-07 Thread Craig Andrews
commit: 8f5765e793e6288b4c589858829d309d68eafa96
Author: Craig Andrews  gentoo  org>
AuthorDate: Tue Apr  7 21:22:08 2020 +
Commit: Craig Andrews  gentoo  org>
CommitDate: Tue Apr  7 21:22:29 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=8f5765e7

media-plugins/kodi-vfs-rar: 2.3.0 version bump

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Craig Andrews  gentoo.org>

 media-plugins/kodi-vfs-rar/Manifest|  1 +
 .../kodi-vfs-rar/kodi-vfs-rar-2.3.0.ebuild | 34 ++
 2 files changed, 35 insertions(+)

diff --git a/media-plugins/kodi-vfs-rar/Manifest 
b/media-plugins/kodi-vfs-rar/Manifest
index c4273426e23..eeda45d2679 100644
--- a/media-plugins/kodi-vfs-rar/Manifest
+++ b/media-plugins/kodi-vfs-rar/Manifest
@@ -2,3 +2,4 @@ DIST kodi-vfs-rar-2.2.0.tar.gz 460340 BLAKE2B 
8362dd0c1d3bb799fa041d2f6ed0e61c4a
 DIST kodi-vfs-rar-2.2.1.tar.gz 455711 BLAKE2B 
b16ce42dc66ddd0f9e8cd4be22ad63fa08cdb5fbdeaeaff4f7b93098650d09530ace2c9bbffc2bb3b39054f0311de81fb0ff15c33a904b63ac6299409c2d887a
 SHA512 
d191973d7ffd1f5f9912e889b292ebed12b58aa7602d4a07ad7593aada5a68b92a593909734ff116a8f815f1cea9ceae60fe4842e5ee6b60199130b3e4a2722e
 DIST kodi-vfs-rar-2.2.2.tar.gz 456689 BLAKE2B 
d874338fce92548bbf3223d103bc1083c78f9fd7799f7f54f689d3adacc64031b70b766fa086ae38b41c9945ae9f08d24080467444a4ac652a03c665d3a4908b
 SHA512 
c03664b4db58251f558202c90b740c5c838745ec47007ad58e378d7237c2b399d57d42779e5dc24c371afcad4f90bc9516d25a4f5f1f7824b8c0d076a1b8cf5c
 DIST kodi-vfs-rar-2.2.3.tar.gz 461697 BLAKE2B 
08315b17e61a2074fca7382e69a6c4d76e75e123492614c0e2f3ccbade888c891b305df591df6f5a785df0a9abdae022f27020045d1db8eff3112f3c7bdd026e
 SHA512 
9adc3fb36366bf14f3cf8229c3efabf6459228b148a19745e5f62230683aa607c94bf36c1739ab32a07ca50a33742e3094f21bc5d47d0fc27b26071fea231736
+DIST kodi-vfs-rar-2.3.0.tar.gz 462195 BLAKE2B 
cc351adff4ca0b130a71606dac3cd2abd0da295b09a80f974ed4bc1fad9c96fbd3d869633d5d8b10fee12b2a1954f89bf989e4c2ef01bc5a5c7bcab055e72580
 SHA512 
8efcae79ee860ad376888e6ca2ef77b68baa64e6e7f82dfa505b341e5fe141f769d5ac3cb4c7b1adb89edde1ae98f684bfdcade5084b403c47b2f3ef877b0a71

diff --git a/media-plugins/kodi-vfs-rar/kodi-vfs-rar-2.3.0.ebuild 
b/media-plugins/kodi-vfs-rar/kodi-vfs-rar-2.3.0.ebuild
new file mode 100644
index 000..800adb13571
--- /dev/null
+++ b/media-plugins/kodi-vfs-rar/kodi-vfs-rar-2.3.0.ebuild
@@ -0,0 +1,34 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit cmake kodi-addon
+
+DESCRIPTION="RAR VFS addon for Kodi"
+HOMEPAGE="https://github.com/xbmc/vfs.rar;
+SRC_URI=""
+
+case ${PV} in
+)
+   SRC_URI=""
+   EGIT_REPO_URI="https://github.com/xbmc/vfs.rar.git;
+   inherit git-r3
+   ;;
+*)
+   CODENAME="Leia"
+   KEYWORDS="~amd64 ~x86"
+   
SRC_URI="https://github.com/xbmc/vfs.rar/archive/${PV}-${CODENAME}.tar.gz -> 
${P}.tar.gz"
+   S="${WORKDIR}/vfs.rar-${PV}-${CODENAME}"
+   ;;
+esac
+
+LICENSE="GPL-2"
+SLOT="0"
+IUSE=""
+
+DEPEND="
+   =dev-libs/libplatform-2*
+   =media-libs/kodi-platform-18*
+   =media-tv/kodi-18*
+   "



[gentoo-commits] repo/gentoo:master commit in: dev-lang/julia/

2020-04-07 Thread Matthias Maier
commit: a36e6964151da25e9bfe820f38a5e69104c5a94c
Author: Matthias Maier  gentoo  org>
AuthorDate: Tue Apr  7 18:04:41 2020 +
Commit: Matthias Maier  gentoo  org>
CommitDate: Tue Apr  7 21:02:51 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=a36e6964

dev-lang/julia: really download all bundled tarballs

Closes: https://bugs.gentoo.org/716434
Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Matthias Maier  gentoo.org>

 dev-lang/julia/Manifest  | 2 ++
 dev-lang/julia/julia-1.4.0-r1.ebuild | 8 ++--
 2 files changed, 8 insertions(+), 2 deletions(-)

diff --git a/dev-lang/julia/Manifest b/dev-lang/julia/Manifest
index fd89339acd8..dbf3cd539b1 100644
--- a/dev-lang/julia/Manifest
+++ b/dev-lang/julia/Manifest
@@ -2,7 +2,9 @@ DIST julia-1.2.0.tar.gz 8255435 BLAKE2B 
286b7bd93cae247c545d9c384e244115f84daee9
 DIST julia-1.3.0.tar.gz 8793136 BLAKE2B 
e469d80c94e3b15b198011e62f591a699ec7218c755cf3e0c1be8f94e2a28e9800a10599a152f6865f534652d22f118bb14cd1886d257a96e6875562bce56f0c
 SHA512 
c7fdc5c4435c82688fe608a7009ccee6d622f51a62578bf2323ad623acfd58bfb6ed1252f81481708b5b428c37292e078ce72b10df3fe32d29158b0726be2c2e
 DIST julia-1.4.0.tar.gz 7239281 BLAKE2B 
f11467cf91c2a72f03f77421537f4089bab6a1596ede27963551819453bea2a3a46cad9a43951df8857120a00a44f2f04eb5e23659ea4d1772feddb00ba85d2c
 SHA512 
f8152a595f13932f6cad186cf2fdf2fb0bd64cc49bbb11a76d8299f4745ca6428823ead0e73a7bae1347f1b99bf1181d1f457587d13a7bfc7324ca81afc35cc1
 DIST julia-Pkg-49908bffe83790bc7cf3c5d46faf3667f8902ad4.tar.gz 389738 BLAKE2B 
1ed9201badf0a1db5142e0566bfe085b364e4681670937ac5fa53c15312ff8eb29d5e783b75fe3f4f379b041ba38c66ce94962fa7d98fcfd0b7b49acd1749d69
 SHA512 
a85aa80b3080794a8e3ae5ce54856e63457c461659c12fde5dde1b5ec33176ea06af49ee516d01ccd7b78d8358de2fe0ffcd5c6a6d5a5088cdcd76a0133780eb
+DIST julia-cacert-2020-01-01.pem 223687 BLAKE2B 
29d2ce73380897a5841deef1c7eb5e61ff3f5c278ab95286bbfdf5b1c4d41ae94402dc5cb376975977f2d31030e0df872273942a1b6cc91b7ff35ecfd7efc1c2
 SHA512 
cc129ae1a4377a43a74b0854b6eccb2b315cdfce018142d1dd5524fb64c8945cde067cb18f366351fa7d6af3f9f36cf21bc1f626f987f9e4627878472ea59cde
 DIST julia-dsfmt-2.2.3.tar.gz 291773 BLAKE2B 
6ffae90494d72527920c80fc0fb005da1c7b84f8a03a7ecb0789434c0fff97359e5098e85431896dffccc7d5148c414e847aaba5feef648b8788421a466ff65e
 SHA512 
6d8ddcd01aab3f9039f4f0288a8af53e290cc2f293ed8c4a8c9f3b3f12398e7eedfce8016117b425766ba89c61c86c13b3e420035b5f9bf91315b8b814c03662
+DIST julia-libgit2-b3e1a56ebb2b9291e82dc027ba9cbcfc3ead54d3.tar.gz 4981505 
BLAKE2B 
b2a414690de2c8eea5247260d76a3ff447e4f925a3c749e88cb9bfe96d1e3086be04534801fdf9d1eb1f8d84c6a6dc0eb4b6401be311ed3d5391ec9d481b1dda
 SHA512 
7384a7eeeb36ac79d4e7e1336546e48f8fc820653f887f944c3902fcaae4e59d855679b39c5279b7372995934e549e34c526e1459a82032206913f9747b3dd08
 DIST julia-libuv-2348256acf5759a544e5ca7935f638d2bc091d60.tar.gz 1555710 
BLAKE2B 
31ce57d23765c142799dd985a5511751d63238cf7e082fd1ad5574bf62201e9d6cb53b8da5dcc724765ccb4abd63da3ca6d6cbd45e078310c2ffa3859d09b8e4
 SHA512 
c8bf3c736a60feb0c6994aa7cd1b80e1a45bd6096aa66db320ddfc27b59a0797d303338ea75978619173e4f0a680254f3db29c9f6d1b84361030cc11c7729c98
 DIST julia-libuv-35b1504507a7a4168caae3d78db54d1121b121e1.tar.gz 1577394 
BLAKE2B 
8ab36f781619f710a64ddc6cf257a4c2f6d27ac22e33ed6f184902d0c6cc3a3941254e0a825071fcd57f869e3ccc5eaf71856539cf6b484358d5aafe383000a9
 SHA512 
5932e9105346e952fd0f51f79898e5b9c993261ec1558408437647ab3b3ce282562f1e0a16db5704cb66e7aa7a4c6a75dd7f0da498a98b1b6af48da88b4869f0
 DIST julia-libwhich-81e9723c0273d78493dc8c8ed570f68d9ce7e89e.tar.gz 4183 
BLAKE2B 
c932e23b1b476d3fd16cf6f451efd5fc6d9c1ec2c53e8ac086340a100817d9b30dae3eff50b284a42c09b2bbae30b9e2fd38b2881f8cbf4974a89f3bd0c87599
 SHA512 
6fb77b715d70d9bc95a8546c3bf97bd3677c7ea344b88bb5bc3bbfac9dceabe8a8cde7a0f64dec884cde802e4a3000e30837d3f824b5a9242348c4fe061526a3

diff --git a/dev-lang/julia/julia-1.4.0-r1.ebuild 
b/dev-lang/julia/julia-1.4.0-r1.ebuild
index fd5891924c7..24fd97a071c 100644
--- a/dev-lang/julia/julia-1.4.0-r1.ebuild
+++ b/dev-lang/julia/julia-1.4.0-r1.ebuild
@@ -8,11 +8,13 @@ RESTRICT="splitdebug"
 inherit llvm pax-utils toolchain-funcs
 
 MY_PV="${PV//_rc/-rc}"
+MY_CACERT_V="2020-01-01"
+MY_DSFMT_V="2.2.3"
+MY_LIBGIT2_V="b3e1a56ebb2b9291e82dc027ba9cbcfc3ead54d3"
 MY_LIBUV_V="35b1504507a7a4168caae3d78db54d1121b121e1"
-MY_UTF8PROC_V="5c632c57426f2e4246e3b64dd2fd088d3920f9e5"
 MY_LIBWHICH_V="81e9723c0273d78493dc8c8ed570f68d9ce7e89e"
-MY_DSFMT_V="2.2.3"
 MY_PKG_V="49908bffe83790bc7cf3c5d46faf3667f8902ad4"
+MY_UTF8PROC_V="5c632c57426f2e4246e3b64dd2fd088d3920f9e5"
 
 DESCRIPTION="High-performance programming language for technical computing"
 HOMEPAGE="https://julialang.org/;
@@ -20,7 +22,9 @@ SRC_URI="

https://github.com/JuliaLang/${PN}/releases/download/v${MY_PV}/${PN}-${MY_PV}.tar.gz
https://api.github.com/repos/JuliaLang/libuv/tarball/${MY_LIBUV_V} -> 
${PN}-libuv-${MY_LIBUV_V}.tar.gz


[gentoo-commits] repo/gentoo:master commit in: dev-python/slackclient/

2020-04-07 Thread Robin H. Johnson
commit: b8c4ad3165847559b0e98b3c12e8ae794a6955d3
Author: Robin H. Johnson  gentoo  org>
AuthorDate: Tue Apr  7 20:55:09 2020 +
Commit: Robin H. Johnson  gentoo  org>
CommitDate: Tue Apr  7 20:55:41 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=b8c4ad31

dev-python/slackclient: build fix

Closes: https://bugs.gentoo.org/716536
Signed-off-by: Robin H. Johnson  gentoo.org>

 dev-python/slackclient/slackclient-2.5.0.ebuild | 9 +
 1 file changed, 9 insertions(+)

diff --git a/dev-python/slackclient/slackclient-2.5.0.ebuild 
b/dev-python/slackclient/slackclient-2.5.0.ebuild
index c5f5e7eec92..2af67b3adc5 100644
--- a/dev-python/slackclient/slackclient-2.5.0.ebuild
+++ b/dev-python/slackclient/slackclient-2.5.0.ebuild
@@ -21,3 +21,12 @@ RDEPEND="
"
 DEPEND="dev-python/setuptools[${PYTHON_USEDEP}]
${RDEPEND}"
+
+src_prepare() {
+   # Upstream uses pytest-runner as an extra optional target in setup.py as
+   # part of tooling to generate distfiles.
+   sed -i \
+   -e '/setup_requires=/s,"pytest-runner",,' \
+   "${S}"/setup.py || die
+   default
+}



[gentoo-commits] repo/gentoo:master commit in: eclass/

2020-04-07 Thread Matt Turner
commit: 85f6ff816dae4e9957b5f39b489ab1ae16e74184
Author: Ben Kohler  gentoo  org>
AuthorDate: Fri Sep  6 16:13:43 2019 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 20:53:47 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=85f6ff81

gnome2-utils.eclass: remove redundant @USAGE lines

Signed-off-by: Ben Kohler  gentoo.org>
Signed-off-by: Matt Turner  gentoo.org>

 eclass/gnome2-utils.eclass | 5 -
 1 file changed, 5 deletions(-)

diff --git a/eclass/gnome2-utils.eclass b/eclass/gnome2-utils.eclass
index 06683a7467f..c9765f6fd91 100644
--- a/eclass/gnome2-utils.eclass
+++ b/eclass/gnome2-utils.eclass
@@ -297,7 +297,6 @@ gnome2_schemas_savelist() {
 }
 
 # @FUNCTION: gnome2_schemas_update
-# @USAGE: gnome2_schemas_update
 # @DESCRIPTION:
 # Updates GSettings schemas.
 # This function should be called from pkg_postinst and pkg_postrm.
@@ -328,7 +327,6 @@ gnome2_gdk_pixbuf_savelist() {
 }
 
 # @FUNCTION: gnome2_gdk_pixbuf_update
-# @USAGE: gnome2_gdk_pixbuf_update
 # @DESCRIPTION:
 # Updates gdk-pixbuf loader cache if GNOME2_ECLASS_GDK_PIXBUF_LOADERS has some.
 # This function should be called from pkg_postinst and pkg_postrm.
@@ -360,7 +358,6 @@ gnome2_gdk_pixbuf_update() {
 }
 
 # @FUNCTION: gnome2_query_immodules_gtk2
-# @USAGE: gnome2_query_immodules_gtk2
 # @DESCRIPTION:
 # Updates gtk2 immodules/gdk-pixbuf loaders listing.
 gnome2_query_immodules_gtk2() {
@@ -374,7 +371,6 @@ gnome2_query_immodules_gtk2() {
 }
 
 # @FUNCTION: gnome2_query_immodules_gtk3
-# @USAGE: gnome2_query_immodules_gtk3
 # @DESCRIPTION:
 # Updates gtk3 immodules/gdk-pixbuf loaders listing.
 gnome2_query_immodules_gtk3() {
@@ -388,7 +384,6 @@ gnome2_query_immodules_gtk3() {
 }
 
 # @FUNCTION: gnome2_giomodule_cache_update
-# @USAGE: gnome2_giomodule_cache_update
 # @DESCRIPTION:
 # Updates glib's gio modules cache.
 # This function should be called from pkg_postinst and pkg_postrm.



[gentoo-commits] repo/gentoo:master commit in: eclass/

2020-04-07 Thread Matt Turner
commit: f0974a38af3c214814c703b50f310cf629529373
Author: Arfrever Frehtes Taifersar Arahesis  Apache  Org>
AuthorDate: Tue Mar 31 20:06:09 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 20:53:47 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=f0974a38

gnome2-utils.eclass: Fix missing "/" with EAPI >= 7.

Bug: https://bugs.gentoo.org/694012
Signed-off-by: Arfrever Frehtes Taifersar Arahesis  Apache.Org>
Signed-off-by: Matt Turner  gentoo.org>

 eclass/gnome2-utils.eclass | 18 +-
 1 file changed, 9 insertions(+), 9 deletions(-)

diff --git a/eclass/gnome2-utils.eclass b/eclass/gnome2-utils.eclass
index c6a721d9cfd..0c92abca8c5 100644
--- a/eclass/gnome2-utils.eclass
+++ b/eclass/gnome2-utils.eclass
@@ -136,15 +136,15 @@ gnome2_gconf_install() {
 
# We are ready to install the GCONF Scheme now
unset GCONF_DISABLE_MAKEFILE_SCHEMA_INSTALL
-   export GCONF_CONFIG_SOURCE="$("${updater}" --get-default-source | sed 
"s;:/;:${ROOT};")"
+   export GCONF_CONFIG_SOURCE="$("${updater}" --get-default-source | sed 
"s;:/;:${ROOT%/}/;")"
 
einfo "Installing GNOME 2 GConf schemas"
 
local F
for F in ${GNOME2_ECLASS_SCHEMAS}; do
-   if [[ -e "${EROOT}${F}" ]]; then
+   if [[ -e "${EROOT%/}/${F}" ]]; then
debug-print "Installing schema: ${F}"
-   "${updater}" --makefile-install-rule "${EROOT}${F}" 
1>/dev/null
+   "${updater}" --makefile-install-rule "${EROOT%/}/${F}" 
1>/dev/null
fi
done
 
@@ -176,15 +176,15 @@ gnome2_gconf_uninstall() {
fi
 
unset GCONF_DISABLE_MAKEFILE_SCHEMA_INSTALL
-   export GCONF_CONFIG_SOURCE="$("${updater}" --get-default-source | sed 
"s;:/;:${ROOT};")"
+   export GCONF_CONFIG_SOURCE="$("${updater}" --get-default-source | sed 
"s;:/;:${ROOT%/}/;")"
 
einfo "Uninstalling GNOME 2 GConf schemas"
 
local F
for F in ${GNOME2_ECLASS_SCHEMAS}; do
-   if [[ -e "${EROOT}${F}" ]]; then
+   if [[ -e "${EROOT%/}/${F}" ]]; then
debug-print "Uninstalling gconf schema: ${F}"
-   "${updater}" --makefile-uninstall-rule "${EROOT}${F}" 
1>/dev/null
+   "${updater}" --makefile-uninstall-rule 
"${EROOT%/}/${F}" 1>/dev/null
fi
done
 
@@ -352,7 +352,7 @@ gnome2_gdk_pixbuf_update() {
local tmp_file=$(emktemp)
${updater} 1> "${tmp_file}" &&
chmod 0644 "${tmp_file}" &&
-   cp -f "${tmp_file}" 
"${EROOT}usr/$(get_libdir)/gdk-pixbuf-2.0/2.10.0/loaders.cache" &&
+   cp -f "${tmp_file}" 
"${EROOT%/}/usr/$(get_libdir)/gdk-pixbuf-2.0/2.10.0/loaders.cache" &&
rm "${tmp_file}" # don't replace this with mv, required for SELinux 
support
eend $?
 }
@@ -365,7 +365,7 @@ gnome2_query_immodules_gtk2() {
[[ ! -x ${updater} ]] && 
updater=${EPREFIX}/usr/bin/gtk-query-immodules-2.0
 
ebegin "Updating gtk2 input method module cache"
-   
GTK_IM_MODULE_FILE="${EROOT}usr/$(get_libdir)/gtk-2.0/2.10.0/immodules.cache" \
+   
GTK_IM_MODULE_FILE="${EROOT%/}/usr/$(get_libdir)/gtk-2.0/2.10.0/immodules.cache"
 \
"${updater}" --update-cache
eend $?
 }
@@ -378,7 +378,7 @@ gnome2_query_immodules_gtk3() {
[[ ! -x ${updater} ]] && 
updater=${EPREFIX}/usr/bin/gtk-query-immodules-3.0
 
ebegin "Updating gtk3 input method module cache"
-   
GTK_IM_MODULE_FILE="${EROOT}usr/$(get_libdir)/gtk-3.0/3.0.0/immodules.cache" \
+   
GTK_IM_MODULE_FILE="${EROOT%/}/usr/$(get_libdir)/gtk-3.0/3.0.0/immodules.cache" 
\
"${updater}" --update-cache
eend $?
 }



[gentoo-commits] repo/gentoo:master commit in: eclass/

2020-04-07 Thread Matt Turner
commit: 410a9670ed9e55034a05118a8cb30561c904d1be
Author: Arfrever Frehtes Taifersar Arahesis  Apache  Org>
AuthorDate: Tue Mar 31 20:06:10 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 20:53:47 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=410a9670

gnome2-utils.eclass: Inherit eutils.eclass for emktemp().

Bug: https://bugs.gentoo.org/694012
Signed-off-by: Arfrever Frehtes Taifersar Arahesis  Apache.Org>
Signed-off-by: Matt Turner  gentoo.org>

 eclass/gnome2-utils.eclass | 5 +++--
 1 file changed, 3 insertions(+), 2 deletions(-)

diff --git a/eclass/gnome2-utils.eclass b/eclass/gnome2-utils.eclass
index 0c92abca8c5..06643db0f60 100644
--- a/eclass/gnome2-utils.eclass
+++ b/eclass/gnome2-utils.eclass
@@ -15,8 +15,9 @@
 #  * scrollkeeper (old Gnome help system) management
 
 [[ ${EAPI:-0} == [012345] ]] && inherit multilib
-[[ ${EAPI:-0} == [0123456] ]] && inherit eutils
-inherit xdg-utils
+# eutils.eclass: emktemp
+# xdg-utils.eclass: xdg_environment_reset, xdg_icon_cache_update
+inherit eutils xdg-utils
 
 case "${EAPI:-0}" in
0|1|2|3|4|5|6|7) ;;



[gentoo-commits] repo/gentoo:master commit in: eclass/

2020-04-07 Thread Matt Turner
commit: 8be00fd2295b99388f2ffd2b44182e00b0eb3aa4
Author: Arfrever Frehtes Taifersar Arahesis  Apache  Org>
AuthorDate: Tue Mar 31 20:06:08 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 20:53:47 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=8be00fd2

gnome2-utils.eclass: Fix double "/" with EAPI < 7.

Bug: https://bugs.gentoo.org/694012
Signed-off-by: Arfrever Frehtes Taifersar Arahesis  Apache.Org>
Signed-off-by: Matt Turner  gentoo.org>

 eclass/gnome2-utils.eclass | 20 ++--
 1 file changed, 10 insertions(+), 10 deletions(-)

diff --git a/eclass/gnome2-utils.eclass b/eclass/gnome2-utils.eclass
index c9765f6fd91..c6a721d9cfd 100644
--- a/eclass/gnome2-utils.eclass
+++ b/eclass/gnome2-utils.eclass
@@ -1,4 +1,4 @@
-# Copyright 1999-2019 Gentoo Authors
+# Copyright 1999-2020 Gentoo Authors
 # Distributed under the terms of the GNU General Public License v2
 
 # @ECLASS: gnome2-utils.eclass
@@ -122,7 +122,7 @@ gnome2_gconf_savelist() {
 # This function should be called from pkg_postinst.
 gnome2_gconf_install() {
has ${EAPI:-0} 0 1 2 && ! use prefix && EROOT="${ROOT}"
-   local updater="${EROOT}${GCONFTOOL_BIN}"
+   local updater="${EROOT%/}${GCONFTOOL_BIN}"
 
if [[ ! -x "${updater}" ]]; then
debug-print "${updater} is not executable"
@@ -163,7 +163,7 @@ gnome2_gconf_install() {
 # database.
 gnome2_gconf_uninstall() {
has ${EAPI:-0} 0 1 2 && ! use prefix && EROOT="${ROOT}"
-   local updater="${EROOT}${GCONFTOOL_BIN}"
+   local updater="${EROOT%/}${GCONFTOOL_BIN}"
 
if [[ ! -x "${updater}" ]]; then
debug-print "${updater} is not executable"
@@ -266,7 +266,7 @@ gnome2_scrollkeeper_savelist() {
 # This function should be called from pkg_postinst and pkg_postrm.
 gnome2_scrollkeeper_update() {
has ${EAPI:-0} 0 1 2 && ! use prefix && EROOT="${ROOT}"
-   local updater="${EROOT}${SCROLLKEEPER_UPDATE_BIN}"
+   local updater="${EROOT%/}${SCROLLKEEPER_UPDATE_BIN}"
 
if [[ ! -x "${updater}" ]] ; then
debug-print "${updater} is not executable"
@@ -279,7 +279,7 @@ gnome2_scrollkeeper_update() {
fi
 
ebegin "Updating scrollkeeper database ..."
-   "${updater}" -q -p "${EROOT}${SCROLLKEEPER_DIR}"
+   "${updater}" -q -p "${EROOT%/}${SCROLLKEEPER_DIR}"
eend $?
 }
 
@@ -302,7 +302,7 @@ gnome2_schemas_savelist() {
 # This function should be called from pkg_postinst and pkg_postrm.
 gnome2_schemas_update() {
has ${EAPI:-0} 0 1 2 && ! use prefix && EROOT="${ROOT}"
-   local updater="${EROOT}${GLIB_COMPILE_SCHEMAS}"
+   local updater="${EROOT%/}${GLIB_COMPILE_SCHEMAS}"
 
if [[ ! -x ${updater} ]]; then
debug-print "${updater} is not executable"
@@ -332,10 +332,10 @@ gnome2_gdk_pixbuf_savelist() {
 # This function should be called from pkg_postinst and pkg_postrm.
 gnome2_gdk_pixbuf_update() {
has ${EAPI:-0} 0 1 2 && ! use prefix && EROOT="${ROOT}"
-   local updater="${EROOT}/usr/bin/${CHOST}-gdk-pixbuf-query-loaders"
+   local updater="${EROOT%/}/usr/bin/${CHOST}-gdk-pixbuf-query-loaders"
 
if [[ ! -x ${updater} ]]; then
-   updater="${EROOT}/usr/bin/gdk-pixbuf-query-loaders"
+   updater="${EROOT%/}/usr/bin/gdk-pixbuf-query-loaders"
fi
 
if [[ ! -x ${updater} ]]; then
@@ -389,10 +389,10 @@ gnome2_query_immodules_gtk3() {
 # This function should be called from pkg_postinst and pkg_postrm.
 gnome2_giomodule_cache_update() {
has ${EAPI:-0} 0 1 2 && ! use prefix && EROOT="${ROOT}"
-   local updater="${EROOT}/usr/bin/${CHOST}-gio-querymodules"
+   local updater="${EROOT%/}/usr/bin/${CHOST}-gio-querymodules"
 
if [[ ! -x ${updater} ]]; then
-   updater="${EROOT}/usr/bin/gio-querymodules"
+   updater="${EROOT%/}/usr/bin/gio-querymodules"
fi
 
if [[ ! -x ${updater} ]]; then



[gentoo-commits] repo/gentoo:master commit in: sys-apps/haveged/

2020-04-07 Thread Anthony G. Basile
commit: 0652a31b4c67c8e7bbd7d6c6e67975b6642c7266
Author: Anthony G. Basile  gentoo  org>
AuthorDate: Tue Apr  7 20:42:31 2020 +
Commit: Anthony G. Basile  gentoo  org>
CommitDate: Tue Apr  7 20:43:02 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=0652a31b

sys-apps/haveged: version bump to 1.9.8

Package-Manager: Portage-2.3.89, Repoman-2.3.20
Signed-off-by: Anthony G. Basile  gentoo.org>

 sys-apps/haveged/Manifest |  1 +
 sys-apps/haveged/haveged-1.9.8.ebuild | 45 +++
 2 files changed, 46 insertions(+)

diff --git a/sys-apps/haveged/Manifest b/sys-apps/haveged/Manifest
index 9063a64f4d4..e43a714ae1c 100644
--- a/sys-apps/haveged/Manifest
+++ b/sys-apps/haveged/Manifest
@@ -1,3 +1,4 @@
 DIST haveged-1.9.2.tar.gz 494682 BLAKE2B 
a972d128b19fecc3d01e17bd4cf6d5ec03ae716c4b4934c73193e03f3d3f9ff3461a8280ec0a20885499fd334343deb193ddc98b0697b2b14f92fff897bbf59b
 SHA512 
65f70950fb90ef9c24ff3bf1b26e19a9cde2bec4749e2e64d5461a51646a20cf610efa2a5014219b8605957afa0084abd2ba11c7dc15f9379afce784971627b8
 DIST haveged-1.9.4.tar.gz 493215 BLAKE2B 
e1a8bbda36c35523c7a0c72a1377d7006440742961f9be4527d52b7e05b176334529ee032f5bdf902e729fcfe045a7a0558dfea7c50a95019747d1158f1e4a19
 SHA512 
20017c7637779c0cfa414233bb67efb2976f92c08e4eb1b7ea41ccd483dad755629d8e05fb8560a2db811fc2ded7d05fa081ab10c59341cb4c206595a964641d
+DIST haveged-1.9.8.tar.gz 494473 BLAKE2B 
3c656221ffc896a1c57cfcfa17524c1e40de04fc5cffa94ce71e0bf11a78b578b9f11f8e7683f2be7150d5ccfeba9eb2f553d9379006f2624bf78d5ed152da74
 SHA512 
6a4012c7ab0ad7df77ae61dd3aca072a7aeca942c180d37c8495009fad13a4c9c0e7bf64a3ffce00e50c06679d4b948c3930a960789a06edf074076cf68d37db
 DIST haveged-1.9.8c.tar.gz 494470 BLAKE2B 
840aa0b985107feb38a7b5823f94de3473e79f75542565e571c4ec9b2640dddcabb09d598e101678defbdd2eb04fe2fc1fb1f8466157e53d7c41272131450dec
 SHA512 
24167e8a9773d96b3c57cd3e57def7e291f3de86873e796cafc1a59d3f89818c6cb8d46d05e5ae4eb2683fc86b313b1acaed7f210724dadb7df3939e1b3900aa

diff --git a/sys-apps/haveged/haveged-1.9.8.ebuild 
b/sys-apps/haveged/haveged-1.9.8.ebuild
new file mode 100644
index 000..c792e4bd61f
--- /dev/null
+++ b/sys-apps/haveged/haveged-1.9.8.ebuild
@@ -0,0 +1,45 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+inherit systemd
+
+DESCRIPTION="A simple entropy daemon using the HAVEGE algorithm"
+HOMEPAGE="http://www.issihosts.com/haveged/;
+SRC_URI="https://github.com/jirka-h/${PN}/archive/v${PV}.tar.gz -> ${P}.tar.gz"
+
+LICENSE="GPL-3+"
+SLOT="0"
+KEYWORDS="~amd64 ~arm ~arm64 ~ppc ~ppc64 ~x86"
+IUSE="selinux static-libs threads"
+
+RDEPEND="
+   !

[gentoo-commits] repo/gentoo:master commit in: profiles/arch/arm64/

2020-04-07 Thread Sergei Trofimovich
commit: 4f9b0f26823321ef987ad3584f32e5986352f71d
Author: Rolf Eike Beer  sf-mail  de>
AuthorDate: Tue Apr  7 20:27:44 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 20:30:20 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=4f9b0f26

profiles/arch/arm64/package.use.mask: dbus-test-runner does not depend on 
bustle anymore

Signed-off-by: Rolf Eike Beer  sf-mail.de>
Signed-off-by: Sergei Trofimovich  gentoo.org>

 profiles/arch/arm64/package.use.mask | 7 +--
 1 file changed, 1 insertion(+), 6 deletions(-)

diff --git a/profiles/arch/arm64/package.use.mask 
b/profiles/arch/arm64/package.use.mask
index 79f8daa4fce..1d9583f8e41 100644
--- a/profiles/arch/arm64/package.use.mask
+++ b/profiles/arch/arm64/package.use.mask
@@ -4,7 +4,7 @@
 # Adam Feldman  (2020-04-06)
 # Mask until gui-libs/gtk-layer-shell is keyworded
 mate-base/mate-panel wayland
-#
+
 # Patrick McLean  (2020-04-03)
 # Lots of deps for little gain
 dev-python/joblib doc
@@ -463,11 +463,6 @@ x11-misc/colord extra-print-profiles
 # keyworded here. Remove mask if this situation changes.
 gnome-extra/sushi office
 
-# Alexandre Rostovtsev  (2012-12-30)
-# requires dev-util/bustle, which is written in haskell
-# remove mask if/when dev-lang/ghc is keywoded for arm
-dev-util/dbus-test-runner test
-
 # Alexandre Rostovtsev  (2012-12-27)
 # remove mask when >=app-editors/gedit-3.6 is keyworded here
 dev-util/devhelp gedit



[gentoo-commits] repo/gentoo:master commit in: profiles/arch/arm/

2020-04-07 Thread Sergei Trofimovich
commit: 0d34e37d53400aa11b52ec17a0888a058050bf0e
Author: Rolf Eike Beer  sf-mail  de>
AuthorDate: Tue Apr  7 20:27:54 2020 +
Commit: Sergei Trofimovich  gentoo  org>
CommitDate: Tue Apr  7 20:30:24 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=0d34e37d

profiles/arch/arm/package.use.mask: dbus-test-runner does not depend on bustle 
anymore

Signed-off-by: Rolf Eike Beer  sf-mail.de>
Signed-off-by: Sergei Trofimovich  gentoo.org>

 profiles/arch/arm/package.use.mask | 5 -
 1 file changed, 5 deletions(-)

diff --git a/profiles/arch/arm/package.use.mask 
b/profiles/arch/arm/package.use.mask
index 3d95ea0a7fb..d149c30940d 100644
--- a/profiles/arch/arm/package.use.mask
+++ b/profiles/arch/arm/package.use.mask
@@ -485,11 +485,6 @@ x11-misc/colord argyllcms extra-print-profiles
 # keyworded here. Remove mask if this situation changes.
 gnome-extra/sushi office
 
-# Alexandre Rostovtsev  (2012-12-30)
-# requires dev-util/bustle, which is written in haskell
-# remove mask if/when dev-lang/ghc is keywoded for arm
-dev-util/dbus-test-runner test
-
 # Markus Meier  (2012-Dez-25)
 # unkeyworded deps for app-accessibility/speech-dispatcher
 app-accessibility/speech-dispatcher flite



[gentoo-commits] repo/gentoo:master commit in: net-misc/axel/

2020-04-07 Thread Piotr Karbowski
commit: 12c51bb7ef6c60c58786e131144e62abdbbfd033
Author: Piotr Karbowski  gentoo  org>
AuthorDate: Tue Apr  7 20:19:11 2020 +
Commit: Piotr Karbowski  gentoo  org>
CommitDate: Tue Apr  7 20:19:11 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=12c51bb7

net-misc/axel-2.17.7: stable (bug 716616)

Signed-off-by: Piotr Karbowski  gentoo.org>

 net-misc/axel/axel-2.17.7.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/net-misc/axel/axel-2.17.7.ebuild b/net-misc/axel/axel-2.17.7.ebuild
index 5a684ef22ff..0843a6a909e 100644
--- a/net-misc/axel/axel-2.17.7.ebuild
+++ b/net-misc/axel/axel-2.17.7.ebuild
@@ -11,7 +11,7 @@ 
SRC_URI="https://github.com/axel-download-accelerator/axel/releases/download/v${
 
 LICENSE="GPL-2"
 SLOT="0"
-KEYWORDS="~amd64 ~hppa ~ppc ~ppc64 ~sparc ~x86 ~amd64-linux ~x86-linux 
~ppc-macos ~x64-macos ~x86-macos ~sparc64-solaris"
+KEYWORDS="amd64 ~hppa ~ppc ~ppc64 ~sparc ~x86 ~amd64-linux ~x86-linux 
~ppc-macos ~x64-macos ~x86-macos ~sparc64-solaris"
 IUSE="debug libressl nls ssl"
 
 CDEPEND="



[gentoo-commits] repo/gentoo:master commit in: net-misc/axel/

2020-04-07 Thread Piotr Karbowski
commit: 0af532ca3698a3d6d7e8272660dbe8df0d3b6799
Author: Piotr Karbowski  gentoo  org>
AuthorDate: Tue Apr  7 19:33:27 2020 +
Commit: Piotr Karbowski  gentoo  org>
CommitDate: Tue Apr  7 19:36:26 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=0af532ca

net-misc/axel-2.17.8: version bump.

Closes: https://bugs.gentoo.org/628792
Signed-off-by: Piotr Karbowski  gentoo.org>

 net-misc/axel/Manifest   |  1 +
 net-misc/axel/axel-2.17.8.ebuild | 41 
 2 files changed, 42 insertions(+)

diff --git a/net-misc/axel/Manifest b/net-misc/axel/Manifest
index a76a15664a9..bf99f58303c 100644
--- a/net-misc/axel/Manifest
+++ b/net-misc/axel/Manifest
@@ -2,4 +2,5 @@ DIST axel-2.12.tar.gz 82995 BLAKE2B 
da6e00cb577ffd9ab55c3b5b4362f0bdbc08ae89572a
 DIST axel-2.14.1.tar.gz 89356 BLAKE2B 
43e278f09304ed9f872c9348fb2113758a046819c6c8667bd6bff65824a8a55c3d0ac647027947f76b9c4f334495284f30066fa3bd60bc0eaab4f4b5b5059620
 SHA512 
72c37fc6def0c765ed8220c27efe22255073b1e3cf1c8f6bda5ee2ce9cd36ac46263ac602a185efd40ca8f197a268612f2dcda69bcb49891c2538b910d971e8b
 DIST axel-2.15.tar.gz 96474 BLAKE2B 
73b35b0c234bf2c21b5c6038979061c908de7520d923ecf6d84d7d6cee348c3e17b8f8d3771909ed74cf20899e3d8ece2cba44764ce625755e0ff44563c0fc43
 SHA512 
b0a516850b56b74fe763df3320b98e47f9977dda208cff9a98a87bdc63e37f5e0fd31d30c240a375f9d992320674983ced8201ee631187149e62b42804c48eb6
 DIST axel-2.17.7.tar.xz 202632 BLAKE2B 
2d799ad39c0742e2edfa09dd19f9d941c54c6136f4d5ec5a95f85d338bdebcc79545205cd1dde6ef25d28c89f494ae3cc278c73e375c9f4a96dabff73b139257
 SHA512 
ed1815199a7cc78897a820e1938a80dba72b83e1b40e6c1e81c6d3457aaa17faf20148a82383768524d61bbabda5b00cdcb2c15ff8ae5ed74e415da0b53be3aa
+DIST axel-2.17.8.tar.xz 201224 BLAKE2B 
0a10187013aa888ae8fa7f165b88955f5a7d63241157f552778c042eaecc7873e10e27537a8c7a26a09df5e655097845037f23a6c39f4d46328d633f944a316a
 SHA512 
9158cc0f1c7b54d84e5c15331ddcf6056b5eb654c0ad068e058eedbea99bb87c1b2e759b57872a86d76d83d6807500989ad6bbf87f1c0210db2d4dab100933ea
 DIST axel-2.4.tar.bz2 44995 BLAKE2B 
03218c6243029695deae1a2d96b4e0cce719cf23602faf2d2fb4422f06ae313f5a1ed6759e7bc59a1ce756a732873ca5faed636742b608b6a66240b694b7189a
 SHA512 
34d73cea19f2bf393aa8d3e4b6c24296f8b1d4e6177da6f4728763e013d5d9d073aa5dae31d0ff175126e8fcbd973daf94674a70f100afc9e7d00b92b78b8ec9

diff --git a/net-misc/axel/axel-2.17.8.ebuild b/net-misc/axel/axel-2.17.8.ebuild
new file mode 100644
index 000..dad9472d967
--- /dev/null
+++ b/net-misc/axel/axel-2.17.8.ebuild
@@ -0,0 +1,41 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit autotools
+
+DESCRIPTION="Light Unix download accelerator"
+HOMEPAGE="https://github.com/axel-download-accelerator/axel;
+SRC_URI="https://github.com/axel-download-accelerator/axel/releases/download/v${PV}/${P}.tar.xz;
+
+LICENSE="GPL-2"
+SLOT="0"
+KEYWORDS="~amd64 ~hppa ~ppc ~ppc64 ~sparc ~x86"
+IUSE="debug libressl nls ssl"
+
+CDEPEND="
+   ssl? (
+   !libressl? ( dev-libs/openssl:0= )
+   libressl? ( dev-libs/libressl:0= )
+   )
+"
+DEPEND="${CDEPEND}
+   nls? ( sys-devel/gettext )"
+RDEPEND="${CDEPEND}
+   nls? ( virtual/libintl virtual/libiconv )"
+
+DOCS=( doc/. )
+
+src_configure() {
+   econf \
+   $(use_enable nls) \
+   $(use_with ssl)
+}
+
+pkg_postinst() {
+   einfo 'To use axel with Portage, one can configure make.conf with:'
+   einfo
+   einfo 'FETCHCOMMAND="axel --timeout=30 --alternate --no-clobber 
--output=\"\${DISTDIR}/\${FILE}\" \"\${URI}\""'
+   einfo 'RESUMECOMMAND="axel --timeout=30 --alternate --no-clobber 
--output=\"\${DISTDIR}/\${FILE}\" \"\${URI}\""'
+}



[gentoo-commits] repo/gentoo:master commit in: app-text/nuspell/

2020-04-07 Thread Sebastian Pipping
commit: d7e6ab993c0132371049bb7b7d7c128fe12f6384
Author: Sebastian Pipping  gentoo  org>
AuthorDate: Tue Apr  7 19:31:00 2020 +
Commit: Sebastian Pipping  gentoo  org>
CommitDate: Tue Apr  7 19:34:02 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=d7e6ab99

app-text/nuspell: 3.1.0

Signed-off-by: Sebastian Pipping  gentoo.org>
Package-Manager: Portage-2.3.92, Repoman-2.3.22

 app-text/nuspell/Manifest |  1 +
 app-text/nuspell/nuspell-3.1.0.ebuild | 48 +++
 2 files changed, 49 insertions(+)

diff --git a/app-text/nuspell/Manifest b/app-text/nuspell/Manifest
index 79e246255be..44824bfdad3 100644
--- a/app-text/nuspell/Manifest
+++ b/app-text/nuspell/Manifest
@@ -1 +1,2 @@
 DIST nuspell-3.0.0.tar.gz 403043 BLAKE2B 
b437012e4fb327f13d9ff0944dadf7e865c670daf153be00dd48e9d2fc01c87d410ebd5aeaa094f6446d3035346738010cdba961cfaada3751bedce264beaa6a
 SHA512 
d9cd7dd276e2bca43dec3abaf11c5206695949b9fda8c9b86f2772cc7e8fa95bf17c685a2ef9ca87fe3c4f0b55f2fcb435bc21c187355f5e3fa35dcafab2c8c2
+DIST nuspell-3.1.0.tar.gz 407196 BLAKE2B 
688f6f59ba2f7bceaafe9a7cc707c008be93341e855ca60f07d6de67a626539693048af6f5ca40246ccc51e2573b76ba2bd4439aa9c0acb66a212bebd9219617
 SHA512 
a9bedfd6e2d77fd34d249cf7aa1fcb6bde5bced26f02f8a2dd860416a61488c9b7016a0df6015052fcccb272b342e6205db601107f46efa44c9d78ce261a826c

diff --git a/app-text/nuspell/nuspell-3.1.0.ebuild 
b/app-text/nuspell/nuspell-3.1.0.ebuild
new file mode 100644
index 000..84d7b5101d0
--- /dev/null
+++ b/app-text/nuspell/nuspell-3.1.0.ebuild
@@ -0,0 +1,48 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit cmake
+
+DESCRIPTION="Spell checker library and CLI for complex natural languages"
+HOMEPAGE="https://nuspell.github.io/ https://github.com/nuspell/nuspell;
+SRC_URI="https://github.com/nuspell/nuspell/archive/v${PV}.tar.gz -> 
${P}.tar.gz"
+
+LICENSE="test? ( || ( MPL-1.1 GPL-2+ LGPL-2.1+ ) ) LGPL-3+"
+SLOT="0/3"  # due to libnuspell.so.3
+KEYWORDS="~amd64 ~x86"
+IUSE="doc test"
+
+RDEPEND="dev-libs/icu"
+DEPEND="${RDEPEND}
+   doc? ( app-text/ronn )
+   test? ( >=dev-cpp/catch-2.3.0:0 )
+   >=dev-libs/boost-1.62[icu]"
+
+DOCS=( CHANGELOG.md )
+
+RESTRICT="!test? ( test )"
+
+src_prepare() {
+   rm -R external || die
+   cmake_src_prepare
+}
+
+src_configure() {
+   local mycmakeargs=(
+   -DBUILD_TESTING=$(usex test)
+   )
+
+   cmake_src_configure
+}
+
+pkg_postinst() {
+   einfo
+   einfo 'Nuspell needs language packs and/or dictionaries to be of use'
+   einfo 'e.g. package app-dicts/myspell-en or one of its siblings.'
+   einfo
+   einfo 'Besides MySpell dictionaries, for other options please'
+   einfo 'see https://nuspell.github.io/#languages-and-users .  Good luck!'
+   einfo
+}



[gentoo-commits] repo/gentoo:master commit in: www-client/google-chrome/

2020-04-07 Thread Mike Gilbert
commit: 5a51c9a32c49c4dbe633a326f1716e48f42548ee
Author: Mike Gilbert  gentoo  org>
AuthorDate: Tue Apr  7 19:31:12 2020 +
Commit: Mike Gilbert  gentoo  org>
CommitDate: Tue Apr  7 19:31:12 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=5a51c9a3

www-client/google-chrome: automated update (81.0.4044.92)

Package-Manager: Portage-2.3.96_p4, Repoman-2.3.22_p1
Signed-off-by: Mike Gilbert  gentoo.org>

 www-client/google-chrome/Manifest   | 2 +-
 ...le-chrome-80.0.3987.163.ebuild => google-chrome-81.0.4044.92.ebuild} | 0
 2 files changed, 1 insertion(+), 1 deletion(-)

diff --git a/www-client/google-chrome/Manifest 
b/www-client/google-chrome/Manifest
index d92f638d455..ec4b0a903a5 100644
--- a/www-client/google-chrome/Manifest
+++ b/www-client/google-chrome/Manifest
@@ -1 +1 @@
-DIST google-chrome-stable_80.0.3987.163-1_amd64.deb 63635666 BLAKE2B 
4088abef9c19cc7f47503e494f35910510a60d2ca918af998c3658eca1a99d6477df5a7e6d0c3dd1761cf4082a7789f85b23fcb08fbf3fbcec6fc53bf886b61b
 SHA512 
22a75fcfdc6924a3177878b3583d627b07b1333fefd03aca664404988ff3f191995164de173c4fe4e3f5482ebe8679ae343f1c1548f9710dfea26520d0def336
+DIST google-chrome-stable_81.0.4044.92-1_amd64.deb 4566 BLAKE2B 
7ebc10f4e6c33431bda44867ecf74e421293240fb350a222977669ff8a1755b7eb1c50976670c78238d7101b89dcb4df5c8e72bfae51c2e57ed7aa3c9938d925
 SHA512 
57bb48cabe2d06f9486fff40b1faff0a5d58867ba54573e317da0e641b12d8c29f7443bb9adec6e3f134ce3916584c1b2357faebbb2c267e651918519e958ae0

diff --git a/www-client/google-chrome/google-chrome-80.0.3987.163.ebuild 
b/www-client/google-chrome/google-chrome-81.0.4044.92.ebuild
similarity index 100%
rename from www-client/google-chrome/google-chrome-80.0.3987.163.ebuild
rename to www-client/google-chrome/google-chrome-81.0.4044.92.ebuild



[gentoo-commits] repo/gentoo:master commit in: www-plugins/chrome-binary-plugins/

2020-04-07 Thread Mike Gilbert
commit: a885a9da5b501401861bb66c2e94616c64041900
Author: Mike Gilbert  gentoo  org>
AuthorDate: Tue Apr  7 19:31:23 2020 +
Commit: Mike Gilbert  gentoo  org>
CommitDate: Tue Apr  7 19:31:23 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=a885a9da

www-plugins/chrome-binary-plugins: automated update (81.0.4044.92)

Package-Manager: Portage-2.3.96_p4, Repoman-2.3.22_p1
Signed-off-by: Mike Gilbert  gentoo.org>

 www-plugins/chrome-binary-plugins/Manifest  | 2 +-
 ...s-80.0.3987.163.ebuild => chrome-binary-plugins-81.0.4044.92.ebuild} | 0
 2 files changed, 1 insertion(+), 1 deletion(-)

diff --git a/www-plugins/chrome-binary-plugins/Manifest 
b/www-plugins/chrome-binary-plugins/Manifest
index 466db8c5f68..add528ec364 100644
--- a/www-plugins/chrome-binary-plugins/Manifest
+++ b/www-plugins/chrome-binary-plugins/Manifest
@@ -1,3 +1,3 @@
 DIST google-chrome-beta_81.0.4044.92-1_amd64.deb 66682918 BLAKE2B 
ccbd44703068663836434abc86d483e3ffef159e2da4e4f43ffaddc607d2478809a53ed2792f2ee2d60d2ee2be64917b3545e0996b2f8509e9f865f848420179
 SHA512 
6288556b21d3aee0c2890eb26e4354a77ccfbba7a0cb9bd2183ac1a633d155372989fa1d7ab37c61eda489f06240c9d4e60a1c6b25bc2bd73343de4b9fc7bf75
-DIST google-chrome-stable_80.0.3987.163-1_amd64.deb 63635666 BLAKE2B 
4088abef9c19cc7f47503e494f35910510a60d2ca918af998c3658eca1a99d6477df5a7e6d0c3dd1761cf4082a7789f85b23fcb08fbf3fbcec6fc53bf886b61b
 SHA512 
22a75fcfdc6924a3177878b3583d627b07b1333fefd03aca664404988ff3f191995164de173c4fe4e3f5482ebe8679ae343f1c1548f9710dfea26520d0def336
+DIST google-chrome-stable_81.0.4044.92-1_amd64.deb 4566 BLAKE2B 
7ebc10f4e6c33431bda44867ecf74e421293240fb350a222977669ff8a1755b7eb1c50976670c78238d7101b89dcb4df5c8e72bfae51c2e57ed7aa3c9938d925
 SHA512 
57bb48cabe2d06f9486fff40b1faff0a5d58867ba54573e317da0e641b12d8c29f7443bb9adec6e3f134ce3916584c1b2357faebbb2c267e651918519e958ae0
 DIST google-chrome-unstable_83.0.4100.3-1_amd64.deb 69282436 BLAKE2B 
625c07b613245e3a4e820560fee276da4f6998c26976c4fab3d4b57d779385cfe33a75cbdd2aae4800de7eaf4eac0fc6646d2c56384f2ac81a4bdec774d03e17
 SHA512 
b6551551b743569b2fcbf8a335016cbcd515532e87db37aec9accd5407c352de98a8a5111f69b0b84f0d34dbc2e06d6f6dace0cd39f8bec2eccc8c3bc43d49ae

diff --git 
a/www-plugins/chrome-binary-plugins/chrome-binary-plugins-80.0.3987.163.ebuild 
b/www-plugins/chrome-binary-plugins/chrome-binary-plugins-81.0.4044.92.ebuild
similarity index 100%
rename from 
www-plugins/chrome-binary-plugins/chrome-binary-plugins-80.0.3987.163.ebuild
rename to 
www-plugins/chrome-binary-plugins/chrome-binary-plugins-81.0.4044.92.ebuild



[gentoo-commits] repo/gentoo:master commit in: net-dns/avahi/

2020-04-07 Thread Matt Turner
commit: c8c9d725bc55bcb19c08f2906f10a1b45bd9ddf5
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 19:17:03 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 19:17:31 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=c8c9d725

net-dns/avahi: Control gtk-sharp dep with IUSE=gtk2

Signed-off-by: Matt Turner  gentoo.org>

 net-dns/avahi/avahi-0.8-r2.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/net-dns/avahi/avahi-0.8-r2.ebuild 
b/net-dns/avahi/avahi-0.8-r2.ebuild
index aaf12d67acb..9b03bd2630e 100644
--- a/net-dns/avahi/avahi-0.8-r2.ebuild
+++ b/net-dns/avahi/avahi-0.8-r2.ebuild
@@ -40,7 +40,7 @@ DEPEND="
introspection? ( dev-libs/gobject-introspection:= )
mono? (
dev-lang/mono
-   gtk? ( dev-dotnet/gtk-sharp:2 )
+   gtk2? ( dev-dotnet/gtk-sharp:2 )
)
python? (
${PYTHON_DEPS}



[gentoo-commits] repo/gentoo:master commit in: app-portage/nattka/

2020-04-07 Thread Michał Górny
commit: 0146fa9a0a3d2d1552385fd7dc2510cd07ddb5a6
Author: Michał Górny  gentoo  org>
AuthorDate: Tue Apr  7 18:50:29 2020 +
Commit: Michał Górny  gentoo  org>
CommitDate: Tue Apr  7 19:00:28 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=0146fa9a

app-portage/nattka: Bump to 0.0.7

Signed-off-by: Michał Górny  gentoo.org>

 app-portage/nattka/Manifest|  1 +
 app-portage/nattka/nattka-0.0.7.ebuild | 28 
 2 files changed, 29 insertions(+)

diff --git a/app-portage/nattka/Manifest b/app-portage/nattka/Manifest
index 8d9805c43f1..edc975e6710 100644
--- a/app-portage/nattka/Manifest
+++ b/app-portage/nattka/Manifest
@@ -1 +1,2 @@
 DIST nattka-0.0.6.tar.gz 60753 BLAKE2B 
cd6d843c34411d4cd3dea32a416dc4d3ade0de3331606cb141804eaaf3ef2f2f0d83160927c701c9266c0bb604180d28631d5c809b11a2332829b1510ddaee18
 SHA512 
b0a5f0d11f0469358464e73dd813b07568bbdccfc66e2c85db8510c7a335b289c7bb51ee2f11fbca84f73453e9f45349882d812859c54ae725afd9580a320135
+DIST nattka-0.0.7.tar.gz 64207 BLAKE2B 
df144feb93ccef79cf9236850c8f286c0cbabfb8ae16bf280cc95552f4e3af2b91872a8dbd624714066147a5af0dcda7085ee828a390f6791da287d0c25a5b1a
 SHA512 
088b3dd470e1c0229278fd2db48d81702572c9294f25ff8f7a72b28866df607aff58f507c9bac9f8b86f4126cc2b6a520761553d38b5f98607f8014132a3d8f0

diff --git a/app-portage/nattka/nattka-0.0.7.ebuild 
b/app-portage/nattka/nattka-0.0.7.ebuild
new file mode 100644
index 000..cf9543a7ac6
--- /dev/null
+++ b/app-portage/nattka/nattka-0.0.7.ebuild
@@ -0,0 +1,28 @@
+# Copyright 2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+DISTUTILS_USE_SETUPTOOLS=rdepend
+PYTHON_COMPAT=( python3_{6,7,8} )
+
+inherit distutils-r1
+
+DESCRIPTION="A New Arch Tester Toolkit -- open-source stable-bot replacement"
+HOMEPAGE="https://github.com/mgorny/nattka/;
+SRC_URI="https://github.com/mgorny/nattka/archive/v${PV}.tar.gz -> ${P}.tar.gz"
+
+LICENSE="BSD-2"
+SLOT="0"
+KEYWORDS="~amd64 ~ppc64 ~x86"
+
+RDEPEND="
+   dev-python/requests[${PYTHON_USEDEP}]
+   dev-util/pkgcheck[${PYTHON_USEDEP}]
+   dev-vcs/git
+   sys-apps/pkgcore[${PYTHON_USEDEP}]"
+BDEPEND="
+   test? ( dev-python/vcrpy[${PYTHON_USEDEP}] )"
+
+distutils_enable_sphinx doc --no-autodoc
+distutils_enable_tests pytest



[gentoo-commits] repo/gentoo:master commit in: dev-ruby/sync/

2020-04-07 Thread Hans de Graaff
commit: 12116cd411eac85f604e4e517c0a76ab2bf42b66
Author: Hans de Graaff  gentoo  org>
AuthorDate: Tue Apr  7 18:22:52 2020 +
Commit: Hans de Graaff  gentoo  org>
CommitDate: Tue Apr  7 18:53:34 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=12116cd4

dev-ruby/sync: initial import of 0.5.0

New dependency for dev-ruby/tins

Package-Manager: Portage-2.3.89, Repoman-2.3.20
Signed-off-by: Hans de Graaff  gentoo.org>

 dev-ruby/sync/Manifest  |  1 +
 dev-ruby/sync/metadata.xml  | 11 +++
 dev-ruby/sync/sync-0.5.0.ebuild | 26 ++
 3 files changed, 38 insertions(+)

diff --git a/dev-ruby/sync/Manifest b/dev-ruby/sync/Manifest
new file mode 100644
index 000..05f6e166adc
--- /dev/null
+++ b/dev-ruby/sync/Manifest
@@ -0,0 +1 @@
+DIST sync-0.5.0.tar.gz 4957 BLAKE2B 
9b4b1710d2468068387d782109199dd45c783b6d7bb0357851f800df2ac4961a72143cfc2b42f522524cf7148694545ae8eab47ee6629062d8ea1505d9095ba0
 SHA512 
5f887d9169e0be834c7fa17ae42b71078f25ce3d83e695490cd136adc1799d6b92e4aed41ce3f3d57b3ad193a1ac4de940b37212c2864bbf6331ba3582128166

diff --git a/dev-ruby/sync/metadata.xml b/dev-ruby/sync/metadata.xml
new file mode 100644
index 000..b57e873
--- /dev/null
+++ b/dev-ruby/sync/metadata.xml
@@ -0,0 +1,11 @@
+
+http://www.gentoo.org/dtd/metadata.dtd;>
+
+  
+r...@gentoo.org
+Gentoo Ruby Project
+  
+  
+ruby/sync
+  
+

diff --git a/dev-ruby/sync/sync-0.5.0.ebuild b/dev-ruby/sync/sync-0.5.0.ebuild
new file mode 100644
index 000..750cc826b25
--- /dev/null
+++ b/dev-ruby/sync/sync-0.5.0.ebuild
@@ -0,0 +1,26 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+USE_RUBY="ruby26 ruby27"
+
+RUBY_FAKEGEM_EXTRADOC="README.md"
+
+RUBY_FAKEGEM_GEMSPEC="${PN}.gemspec"
+
+RUBY_FAKEGEM_BINWRAP=""
+
+inherit ruby-fakegem
+
+DESCRIPTION="A module that provides a two-phase lock with a counter"
+HOMEPAGE="https://github.com/ruby/sync;
+SRC_URI="https://github.com/ruby/sync/archive/v${PV}.tar.gz -> ${P}.tar.gz"
+
+LICENSE="BSD-2"
+SLOT="$(ver_cut 1)"
+KEYWORDS="~amd64"
+IUSE=""
+
+all_ruby_prepare() {
+   sed -i -e 's:require_relative ":require "./:' ${RUBY_FAKEGEM_GEMSPEC} 
|| die
+}



[gentoo-commits] repo/gentoo:master commit in: dev-ruby/term-ansicolor/

2020-04-07 Thread Hans de Graaff
commit: afb6e79335c6a96e9aaac3f4f63a5e8ef65a1f4e
Author: Hans de Graaff  gentoo  org>
AuthorDate: Tue Apr  7 18:50:19 2020 +
Commit: Hans de Graaff  gentoo  org>
CommitDate: Tue Apr  7 18:53:36 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=afb6e793

dev-ruby/term-ansicolor: add ruby27

Package-Manager: Portage-2.3.89, Repoman-2.3.20
Signed-off-by: Hans de Graaff  gentoo.org>

 dev-ruby/term-ansicolor/term-ansicolor-1.7.1.ebuild | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)

diff --git a/dev-ruby/term-ansicolor/term-ansicolor-1.7.1.ebuild 
b/dev-ruby/term-ansicolor/term-ansicolor-1.7.1.ebuild
index 03e0f7a031b..a8544f92c56 100644
--- a/dev-ruby/term-ansicolor/term-ansicolor-1.7.1.ebuild
+++ b/dev-ruby/term-ansicolor/term-ansicolor-1.7.1.ebuild
@@ -2,7 +2,7 @@
 # Distributed under the terms of the GNU General Public License v2
 
 EAPI=6
-USE_RUBY="ruby23 ruby24 ruby25 ruby26"
+USE_RUBY="ruby24 ruby25 ruby26 ruby27"
 
 RUBY_FAKEGEM_RECIPE_DOC="rdoc"
 RUBY_FAKEGEM_RECIPE_TEST="none"
@@ -23,7 +23,7 @@ IUSE=""
 ruby_add_rdepend ">=dev-ruby/tins-1.0"
 
 each_ruby_test() {
-   ${RUBY} -Ilib -S testrb-2 tests/*_test.rb || die
+   ${RUBY} -Ilib:.:tests -e 'Dir["tests/*_test.rb"].each{|f| require f}' 
|| die
 }
 
 all_ruby_install() {



[gentoo-commits] repo/gentoo:master commit in: dev-ruby/tins/

2020-04-07 Thread Hans de Graaff
commit: 320c84f00aeac7c6c57b825c170cde98acabc6d2
Author: Hans de Graaff  gentoo  org>
AuthorDate: Tue Apr  7 18:31:20 2020 +
Commit: Hans de Graaff  gentoo  org>
CommitDate: Tue Apr  7 18:53:35 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=320c84f0

dev-ruby/tins: add 1.24.1

Package-Manager: Portage-2.3.89, Repoman-2.3.20
Signed-off-by: Hans de Graaff  gentoo.org>

 dev-ruby/tins/Manifest   |  1 +
 dev-ruby/tins/tins-1.24.1.ebuild | 30 ++
 2 files changed, 31 insertions(+)

diff --git a/dev-ruby/tins/Manifest b/dev-ruby/tins/Manifest
index e5856cd4416..876f7c2ada9 100644
--- a/dev-ruby/tins/Manifest
+++ b/dev-ruby/tins/Manifest
@@ -2,3 +2,4 @@ DIST tins-1.20.2.gem 305664 BLAKE2B 
37d206664077aa1ba8bac395e076b448797c9d73f469
 DIST tins-1.20.3.gem 305664 BLAKE2B 
26c78cf94acba6651c631b274a98cc7e19d3e215a450d255886d201c5bf94c343141edeb03456a178943cf70efbc9b75ea12cc2ccaec5c929fe5b2c08e918d2c
 SHA512 
f5f723402096e869a8e44e64db9dcd0be4620812f0b5cc291df79010fcb87774ad56298de328242c96ce9dca64f7313271b9fec8cff758a6b3b689bec17c965d
 DIST tins-1.21.1.gem 305664 BLAKE2B 
1a86b55f0334d4e28fe4d4e67c12103ab4ed53056fb00d9d375ffc9b8213419bf277c37d23970e99c6bd7d3a2035cdde661dd63524b81082739d01271370be9c
 SHA512 
25288e3c8e633bc9cef11b988bf778e75a304a52146a4501cd3ebbeee4c845a6be795d4ce7d01b24ff4a9a122fc16afbc20d9d88f7b1559c9b433d8f9282e29d
 DIST tins-1.22.2.gem 306688 BLAKE2B 
c5b0aed29b763d37707de47a57419d9af934a0949417003707fd13a7e9e4a0d82fb905843ceac75a384c6ca9592471c15bc28ea63af4890ce54076f5c2f67d7c
 SHA512 
6b93242d9c63a84de690c381086fd454714cdb0e82ce6eda4deb5d66a8b9ca4bbc5e2c502c258045b06aecb76487eddd019ca267b872717df36cdaf840ae97e7
+DIST tins-1.24.1.gem 306688 BLAKE2B 
64020840eca05dc90402310d2f66a8af2a029954ae8f7b37275c257fc402cc7a6c4f75d8a8f506edf49531b6e1d16112db63094f76736e2e3ee213fb88c92b98
 SHA512 
3df7a43e63f42d48033410affc5b5990864c563c294678b9070bb4dc9c9d47d3783d4e8fc9c4280f6e00304781dae40585df73a8deaac1f228bfc5dadb961b38

diff --git a/dev-ruby/tins/tins-1.24.1.ebuild b/dev-ruby/tins/tins-1.24.1.ebuild
new file mode 100644
index 000..0ae7ba411b9
--- /dev/null
+++ b/dev-ruby/tins/tins-1.24.1.ebuild
@@ -0,0 +1,30 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+USE_RUBY="ruby24 ruby25 ruby26 ruby27"
+
+RUBY_FAKEGEM_RECIPE_TEST="none"
+
+RUBY_FAKEGEM_EXTRADOC="README.md"
+
+RUBY_FAKEGEM_GEMSPEC="${PN}.gemspec"
+
+inherit ruby-fakegem
+
+DESCRIPTION="All the stuff that isn't good enough for a real library"
+HOMEPAGE="https://github.com/flori/tins;
+
+LICENSE="MIT"
+SLOT="0"
+KEYWORDS="~alpha ~amd64 ~arm ~hppa ~ia64 ~ppc ~ppc64 ~sparc ~x86"
+IUSE=""
+
+# Earlier versions of ruby bundled this dependency
+USE_RUBY="ruby26 ruby27" ruby_add_rdepend "dev-ruby/sync"
+
+ruby_add_bdepend "test? ( >=dev-ruby/test-unit-2.5.1-r1 )"
+
+each_ruby_test() {
+   ruby-ng_testrb-2 -Ilib tests/*_test.rb
+}



[gentoo-commits] repo/gentoo:master commit in: dev-ruby/tins/

2020-04-07 Thread Hans de Graaff
commit: 3377460ae43c3a966e46fd51540fa18da654306d
Author: Hans de Graaff  gentoo  org>
AuthorDate: Tue Apr  7 18:47:12 2020 +
Commit: Hans de Graaff  gentoo  org>
CommitDate: Tue Apr  7 18:53:36 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=3377460a

dev-ruby/tins: fix gemspecs

Only include dev-ruby/sync on supported ruby versions.

Package-Manager: Portage-2.3.89, Repoman-2.3.20
Signed-off-by: Hans de Graaff  gentoo.org>

 dev-ruby/tins/tins-1.24.1.ebuild | 8 
 1 file changed, 8 insertions(+)

diff --git a/dev-ruby/tins/tins-1.24.1.ebuild b/dev-ruby/tins/tins-1.24.1.ebuild
index 0ae7ba411b9..9f9ef0959bd 100644
--- a/dev-ruby/tins/tins-1.24.1.ebuild
+++ b/dev-ruby/tins/tins-1.24.1.ebuild
@@ -25,6 +25,14 @@ USE_RUBY="ruby26 ruby27" ruby_add_rdepend "dev-ruby/sync"
 
 ruby_add_bdepend "test? ( >=dev-ruby/test-unit-2.5.1-r1 )"
 
+each_ruby_prepare() {
+   case ${RUBY} in
+   *ruby24|*ruby25)
+   sed -i -e '/sync/d' ${RUBY_FAKEGEM_GEMSPEC} || die
+   ;;
+   esac
+}
+
 each_ruby_test() {
ruby-ng_testrb-2 -Ilib tests/*_test.rb
 }



[gentoo-commits] repo/gentoo:master commit in: dev-ruby/sync/

2020-04-07 Thread Hans de Graaff
commit: 41d0627f745d5f0a4edb62925da19e1fe0b83c5f
Author: Hans de Graaff  gentoo  org>
AuthorDate: Tue Apr  7 18:30:36 2020 +
Commit: Hans de Graaff  gentoo  org>
CommitDate: Tue Apr  7 18:53:35 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=41d0627f

dev-ruby/sync: add keywords

This code was extracted from dev-lang/ruby, so add keywords
relevant for the dev-ruby/tins dependency.

Package-Manager: Portage-2.3.89, Repoman-2.3.20
Signed-off-by: Hans de Graaff  gentoo.org>

 dev-ruby/sync/sync-0.5.0.ebuild | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/dev-ruby/sync/sync-0.5.0.ebuild b/dev-ruby/sync/sync-0.5.0.ebuild
index 750cc826b25..d0673833598 100644
--- a/dev-ruby/sync/sync-0.5.0.ebuild
+++ b/dev-ruby/sync/sync-0.5.0.ebuild
@@ -18,7 +18,7 @@ SRC_URI="https://github.com/ruby/sync/archive/v${PV}.tar.gz 
-> ${P}.tar.gz"
 
 LICENSE="BSD-2"
 SLOT="$(ver_cut 1)"
-KEYWORDS="~amd64"
+KEYWORDS="~alpha ~amd64 ~arm ~ia64 ~ppc ~ppc64 ~x86 ~hppa ~sparc"
 IUSE=""
 
 all_ruby_prepare() {



[gentoo-commits] repo/gentoo:master commit in: mate-base/mate-menus/files/, mate-base/mate-menus/

2020-04-07 Thread Adam Feldman
commit: 3f397745b83622b8029220a85e32601ca9d16eb6
Author: Adam Feldman  gentoo  org>
AuthorDate: Tue Apr  7 18:49:40 2020 +
Commit: Adam Feldman  gentoo  org>
CommitDate: Tue Apr  7 18:50:43 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=3f397745

mate-base/mate-menus: Finish cleaneup of #64

Bug: https://bugs.gentoo.org/64
Package-Manager: Portage-2.3.96, Repoman-2.3.21
Signed-off-by: Adam Feldman  gentoo.org>

 mate-base/mate-menus/files/10-xdg-menu-mate-r1   | 9 +
 .../{mate-menus-1.22.1.ebuild => mate-menus-1.22.1-r1.ebuild}| 2 +-
 .../{mate-menus-1.24.0.ebuild => mate-menus-1.24.0-r1.ebuild}| 2 +-
 3 files changed, 11 insertions(+), 2 deletions(-)

diff --git a/mate-base/mate-menus/files/10-xdg-menu-mate-r1 
b/mate-base/mate-menus/files/10-xdg-menu-mate-r1
new file mode 100644
index 000..01a5610c085
--- /dev/null
+++ b/mate-base/mate-menus/files/10-xdg-menu-mate-r1
@@ -0,0 +1,9 @@
+#!/bin/sh
+
+if [ -z "$XDG_MENU_PREFIX" ] && \
+   [ "$XDG_CURRENT_DESKTOP" = "MATE" -o \
+   "$XDG_SESSION_DESKTOP" = "mate" -o \
+   "$DESKTOP_SESSION" = "mate" ]
+then
+   export XDG_MENU_PREFIX=mate-
+fi

diff --git a/mate-base/mate-menus/mate-menus-1.22.1.ebuild 
b/mate-base/mate-menus/mate-menus-1.22.1-r1.ebuild
similarity index 93%
rename from mate-base/mate-menus/mate-menus-1.22.1.ebuild
rename to mate-base/mate-menus/mate-menus-1.22.1-r1.ebuild
index c93dbf13c79..aa489e3e46e 100644
--- a/mate-base/mate-menus/mate-menus-1.22.1.ebuild
+++ b/mate-base/mate-menus/mate-menus-1.22.1-r1.ebuild
@@ -40,5 +40,5 @@ src_install() {
mate_src_install
 
exeinto /etc/X11/xinit/xinitrc.d/
-   doexe "${FILESDIR}/10-xdg-menu-mate"
+   newexe "${FILESDIR}/10-xdg-menu-mate-r1" "10-xdg-menu-mate"
 }

diff --git a/mate-base/mate-menus/mate-menus-1.24.0.ebuild 
b/mate-base/mate-menus/mate-menus-1.24.0-r1.ebuild
similarity index 93%
rename from mate-base/mate-menus/mate-menus-1.24.0.ebuild
rename to mate-base/mate-menus/mate-menus-1.24.0-r1.ebuild
index e927b3f8c6d..e0a404983b3 100644
--- a/mate-base/mate-menus/mate-menus-1.24.0.ebuild
+++ b/mate-base/mate-menus/mate-menus-1.24.0-r1.ebuild
@@ -38,5 +38,5 @@ src_install() {
mate_src_install
 
exeinto /etc/X11/xinit/xinitrc.d/
-   doexe "${FILESDIR}/10-xdg-menu-mate"
+   newexe "${FILESDIR}/10-xdg-menu-mate-r1" "10-xdg-menu-mate"
 }



[gentoo-commits] repo/gentoo:master commit in: dev-ml/num/

2020-04-07 Thread Alfredo Tupone
commit: a5590b6514a5b93c85532b54a4cb81e03a8a5174
Author: Alfredo Tupone  gentoo  org>
AuthorDate: Tue Apr  7 18:41:04 2020 +
Commit: Alfredo Tupone  gentoo  org>
CommitDate: Tue Apr  7 18:41:04 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=a5590b65

dev-ml/num: use ocamlopt

Closes: https://bugs.gentoo.org/710892
Package-Manager: Portage-2.3.89, Repoman-2.3.20
Signed-off-by: Alfredo Tupone  gentoo.org>

 dev-ml/num/metadata.xml   | 5 -
 dev-ml/num/num-1.3.ebuild | 4 ++--
 2 files changed, 6 insertions(+), 3 deletions(-)

diff --git a/dev-ml/num/metadata.xml b/dev-ml/num/metadata.xml
index bca0744b282..d0e866f244f 100644
--- a/dev-ml/num/metadata.xml
+++ b/dev-ml/num/metadata.xml
@@ -1,5 +1,8 @@
 
 http://www.gentoo.org/dtd/metadata.dtd;>
 
-
+   
+   tup...@gentoo.org
+   Tupone Alfredo
+   
 

diff --git a/dev-ml/num/num-1.3.ebuild b/dev-ml/num/num-1.3.ebuild
index e8cffd40ddb..0f68ec7d75b 100644
--- a/dev-ml/num/num-1.3.ebuild
+++ b/dev-ml/num/num-1.3.ebuild
@@ -14,8 +14,8 @@ SLOT="0"
 KEYWORDS="~amd64 ~x86"
 IUSE=""
 
-DEPEND=">=dev-lang/ocaml-4.09.0
-   >=dev-ml/findlib-1.8.1"
+DEPEND=">=dev-lang/ocaml-4.09.0[ocamlopt]
+   >=dev-ml/findlib-1.8.1[ocamlopt]"
 RDEPEND="${DEPEND}"
 BDEPEND="${DEPEND}"
 



[gentoo-commits] repo/gentoo:master commit in: mate-extra/caja-admin/

2020-04-07 Thread Adam Feldman
commit: 553c77e9192e10c0982d46a347397eed07fadd97
Author: Adam Feldman  gentoo  org>
AuthorDate: Tue Apr  7 04:05:50 2020 +
Commit: Adam Feldman  gentoo  org>
CommitDate: Tue Apr  7 18:31:11 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=553c77e9

mate-extra/caja-admin: Fix QA warnings

Package-Manager: Portage-2.3.96, Repoman-2.3.21
Signed-off-by: Adam Feldman  gentoo.org>

 mate-extra/caja-admin/Manifest  | 4 ++--
 mate-extra/caja-admin/caja-admin-0.0.1.ebuild   | 2 +-
 mate-extra/caja-admin/caja-admin-0.0.2.ebuild   | 2 +-
 mate-extra/caja-admin/caja-admin-0.0.2_p20200328.ebuild | 2 +-
 mate-extra/caja-admin/caja-admin-.ebuild| 2 +-
 mate-extra/caja-admin/metadata.xml  | 4 +++-
 6 files changed, 9 insertions(+), 7 deletions(-)

diff --git a/mate-extra/caja-admin/Manifest b/mate-extra/caja-admin/Manifest
index 58fdbbd4862..81f609eadfc 100644
--- a/mate-extra/caja-admin/Manifest
+++ b/mate-extra/caja-admin/Manifest
@@ -1,3 +1,3 @@
-DIST 0.0.1.tar.gz 26920 BLAKE2B 
29aa35ef185cd588fd9242ea2b019cb64c4a4965b77523937b8b36c3a3437f7171dac3a000b85d9c4183a962a9dc6be787589408c7804f696aeac3576b7fee50
 SHA512 
12f54aad32ac11d34ee8344d564d31f29a53324308923e54426ac3837702e71701cf139b150ec3ff210fb0739eb9c46b05c6380d8596031f71b71899800b767d
-DIST 0.0.2.tar.gz 27564 BLAKE2B 
975bbba48508ed6a997190ea6d5432330710ee312fe6f1e130b47894331a35c32071a40691cf69f617d268ab85dca62bb8bb4577d49bdb3c75c65ce05b4b9220
 SHA512 
919a92e258585e4b6275d346c82a1f9fc90462aa0cdedafb78867b80496f44bbd3459ce5a67429c5dda499bff2928a014779e81c781278ac0603f6cbebd3ff9e
+DIST caja-admin-0.0.1.tar.gz 26920 BLAKE2B 
29aa35ef185cd588fd9242ea2b019cb64c4a4965b77523937b8b36c3a3437f7171dac3a000b85d9c4183a962a9dc6be787589408c7804f696aeac3576b7fee50
 SHA512 
12f54aad32ac11d34ee8344d564d31f29a53324308923e54426ac3837702e71701cf139b150ec3ff210fb0739eb9c46b05c6380d8596031f71b71899800b767d
+DIST caja-admin-0.0.2.tar.gz 27564 BLAKE2B 
975bbba48508ed6a997190ea6d5432330710ee312fe6f1e130b47894331a35c32071a40691cf69f617d268ab85dca62bb8bb4577d49bdb3c75c65ce05b4b9220
 SHA512 
919a92e258585e4b6275d346c82a1f9fc90462aa0cdedafb78867b80496f44bbd3459ce5a67429c5dda499bff2928a014779e81c781278ac0603f6cbebd3ff9e
 DIST caja-admin-0.0.2_p20200328.tar.gz 27087 BLAKE2B 
1d8ce82026249cff4dc3360cedffb79079e6608414a7718f265a19fce1a579d7f1fc4dadf3b05dd5ef19dbd12a92a61f90c04736cc9196d2dd5d4230c8c31784
 SHA512 
6a134e1d53bbdbf1a617582de67f7ddba7c7e0193a714246993092dd1c96c2ccc05afdb2da5cd2dfd974f7ab95e0aeedab244f2fa1335fd157ce45b4404a1f90

diff --git a/mate-extra/caja-admin/caja-admin-0.0.1.ebuild 
b/mate-extra/caja-admin/caja-admin-0.0.1.ebuild
index 60be2b970af..0f9713cd71c 100644
--- a/mate-extra/caja-admin/caja-admin-0.0.1.ebuild
+++ b/mate-extra/caja-admin/caja-admin-0.0.1.ebuild
@@ -12,7 +12,7 @@ elif [[ ${PV} =~ _p[0-9]{8,} ]]; then
KEYWORDS="~amd64 ~x86"
S="${WORKDIR}/${PN}-${SHA}"
 else
-   SRC_URI="https://github.com/infirit/${PN}/archive/${PV}.tar.gz;
+   SRC_URI="https://github.com/infirit/${PN}/archive/${PV}.tar.gz -> 
${P}.tar.gz"
KEYWORDS="~amd64 ~x86"
 fi
 

diff --git a/mate-extra/caja-admin/caja-admin-0.0.2.ebuild 
b/mate-extra/caja-admin/caja-admin-0.0.2.ebuild
index 2e831ad327a..430515a518a 100644
--- a/mate-extra/caja-admin/caja-admin-0.0.2.ebuild
+++ b/mate-extra/caja-admin/caja-admin-0.0.2.ebuild
@@ -12,7 +12,7 @@ elif [[ ${PV} =~ _p[0-9]{8,} ]]; then
KEYWORDS="~amd64 ~x86"
S="${WORKDIR}/${PN}-${SHA}"
 else
-   SRC_URI="https://github.com/infirit/${PN}/archive/${PV}.tar.gz;
+   SRC_URI="https://github.com/infirit/${PN}/archive/${PV}.tar.gz -> 
${P}.tar.gz"
KEYWORDS="~amd64 ~x86"
 fi
 

diff --git a/mate-extra/caja-admin/caja-admin-0.0.2_p20200328.ebuild 
b/mate-extra/caja-admin/caja-admin-0.0.2_p20200328.ebuild
index c28a2709c4a..ec008ecc87f 100644
--- a/mate-extra/caja-admin/caja-admin-0.0.2_p20200328.ebuild
+++ b/mate-extra/caja-admin/caja-admin-0.0.2_p20200328.ebuild
@@ -12,7 +12,7 @@ elif [[ ${PV} =~ _p[0-9]{8,} ]]; then
KEYWORDS="~amd64 ~x86"
S="${WORKDIR}/${PN}-${SHA}"
 else
-   SRC_URI="https://github.com/infirit/${PN}/archive/${PV}.tar.gz;
+   SRC_URI="https://github.com/infirit/${PN}/archive/${PV}.tar.gz -> 
${P}.tar.gz"
KEYWORDS="~amd64 ~x86"
 fi
 

diff --git a/mate-extra/caja-admin/caja-admin-.ebuild 
b/mate-extra/caja-admin/caja-admin-.ebuild
index c28a2709c4a..ec008ecc87f 100644
--- a/mate-extra/caja-admin/caja-admin-.ebuild
+++ b/mate-extra/caja-admin/caja-admin-.ebuild
@@ -12,7 +12,7 @@ elif [[ ${PV} =~ _p[0-9]{8,} ]]; then
KEYWORDS="~amd64 ~x86"
S="${WORKDIR}/${PN}-${SHA}"
 else
-   SRC_URI="https://github.com/infirit/${PN}/archive/${PV}.tar.gz;
+   SRC_URI="https://github.com/infirit/${PN}/archive/${PV}.tar.gz -> 
${P}.tar.gz"
KEYWORDS="~amd64 ~x86"
 fi
 

diff --git 

[gentoo-commits] repo/gentoo:master commit in: mate-base/mate-session-manager/, mate-base/mate-session-manager/files/

2020-04-07 Thread Adam Feldman
commit: 118c72a585b3dd6db178db38f2938e7048a1a13b
Author: Adam Feldman  gentoo  org>
AuthorDate: Tue Apr  7 18:05:30 2020 +
Commit: Adam Feldman  gentoo  org>
CommitDate: Tue Apr  7 18:31:12 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=118c72a5

mate-base/mate-session-manager: Fix typo and to hopefully be foolproof

Thanks to Joakim Tjerlund for pointing it out.
Bug: https://bugs.gentoo.org/64
Package-Manager: Portage-2.3.96, Repoman-2.3.21
Signed-off-by: Adam Feldman  gentoo.org>

 .../{10-user-dirs-update-mate-r1 => 10-user-dirs-update-mate-r2}  | 4 +++-
 .../files/{15-xdg-data-mate-r1 => 15-xdg-data-mate-r2}| 4 +++-
 ...manager-1.22.3-r1.ebuild => mate-session-manager-1.22.3-r2.ebuild} | 4 ++--
 ...manager-1.24.0-r1.ebuild => mate-session-manager-1.24.0-r2.ebuild} | 4 ++--
 4 files changed, 10 insertions(+), 6 deletions(-)

diff --git a/mate-base/mate-session-manager/files/10-user-dirs-update-mate-r1 
b/mate-base/mate-session-manager/files/10-user-dirs-update-mate-r2
similarity index 65%
rename from mate-base/mate-session-manager/files/10-user-dirs-update-mate-r1
rename to mate-base/mate-session-manager/files/10-user-dirs-update-mate-r2
index 994d978dcb3..fd58c0a5b27 100644
--- a/mate-base/mate-session-manager/files/10-user-dirs-update-mate-r1
+++ b/mate-base/mate-session-manager/files/10-user-dirs-update-mate-r2
@@ -3,7 +3,9 @@
 # Create various XDG directories, and write ~/.config/user-dirs.dirs, etc.
 # That file is read by glib to get XDG_PICTURES_DIR, etc
 
-if [ "$XDG_CURRENT_DESKTOP" = "MATE" ]; then
+if [ "$XDG_CURRENT_DESKTOP" = "MATE" -o \
+   "$XDG_SESSION_DESKTOP" = "mate" -o \
+   "$DESKTOP_SESSION" = "mate" ]; then
if type xdg-user-dirs-update >/dev/null 2>&1; then
xdg-user-dirs-update
fi

diff --git a/mate-base/mate-session-manager/files/15-xdg-data-mate-r1 
b/mate-base/mate-session-manager/files/15-xdg-data-mate-r2
similarity index 61%
rename from mate-base/mate-session-manager/files/15-xdg-data-mate-r1
rename to mate-base/mate-session-manager/files/15-xdg-data-mate-r2
index 8bf113e6882..40f2fd13b34 100644
--- a/mate-base/mate-session-manager/files/15-xdg-data-mate-r1
+++ b/mate-base/mate-session-manager/files/15-xdg-data-mate-r2
@@ -1,6 +1,8 @@
 #!/bin/sh
 
-if [ "$XDG_DESKTOP_SESSION" = "MATE" ]; then
+if [ "$XDG_CURRENT_DESKTOP" = "MATE" -o \
+   "$XDG_SESSION_DESKTOP" = "mate" -o \
+   "$DESKTOP_SESSION" = "mate" ]; then
if [ -z "$XDG_DATA_DIRS" ]; then
export 
XDG_DATA_DIRS=/usr/share/mate:/usr/local/share/:/usr/share/
else

diff --git 
a/mate-base/mate-session-manager/mate-session-manager-1.22.3-r1.ebuild 
b/mate-base/mate-session-manager/mate-session-manager-1.22.3-r2.ebuild
similarity index 94%
rename from mate-base/mate-session-manager/mate-session-manager-1.22.3-r1.ebuild
rename to mate-base/mate-session-manager/mate-session-manager-1.22.3-r2.ebuild
index 9eb1d35adf5..a359dd0028c 100644
--- a/mate-base/mate-session-manager/mate-session-manager-1.22.3-r1.ebuild
+++ b/mate-base/mate-session-manager/mate-session-manager-1.22.3-r2.ebuild
@@ -83,8 +83,8 @@ src_install() {
 
dodir /etc/X11/xinit/xinitrc.d/
exeinto /etc/X11/xinit/xinitrc.d/
-   newexe "${FILESDIR}"/15-xdg-data-mate-r1 15-xdg-data-mate
+   newexe "${FILESDIR}"/15-xdg-data-mate-r2 15-xdg-data-mate
 
# This should be done in MATE too, see Gentoo bug #270852
-   newexe "${FILESDIR}"/10-user-dirs-update-mate-r1 
10-user-dirs-update-mate
+   newexe "${FILESDIR}"/10-user-dirs-update-mate-r2 
10-user-dirs-update-mate
 }

diff --git 
a/mate-base/mate-session-manager/mate-session-manager-1.24.0-r1.ebuild 
b/mate-base/mate-session-manager/mate-session-manager-1.24.0-r2.ebuild
similarity index 94%
rename from mate-base/mate-session-manager/mate-session-manager-1.24.0-r1.ebuild
rename to mate-base/mate-session-manager/mate-session-manager-1.24.0-r2.ebuild
index 1788d072af1..3e6f3ca5013 100644
--- a/mate-base/mate-session-manager/mate-session-manager-1.24.0-r1.ebuild
+++ b/mate-base/mate-session-manager/mate-session-manager-1.24.0-r2.ebuild
@@ -82,8 +82,8 @@ src_install() {
 
dodir /etc/X11/xinit/xinitrc.d/
exeinto /etc/X11/xinit/xinitrc.d/
-   newexe "${FILESDIR}"/15-xdg-data-mate-r1 15-xdg-data-mate
+   newexe "${FILESDIR}"/15-xdg-data-mate-r2 15-xdg-data-mate
 
# This should be done in MATE too, see Gentoo bug #270852
-   newexe "${FILESDIR}"/10-user-dirs-update-mate-r1 
10-user-dirs-update-mate
+   newexe "${FILESDIR}"/10-user-dirs-update-mate-r2 
10-user-dirs-update-mate
 }



[gentoo-commits] repo/gentoo:master commit in: media-libs/harfbuzz/

2020-04-07 Thread Lars Wendler
commit: a13a78e091364354955a357603bf9120990f20ac
Author: Lars Wendler  gentoo  org>
AuthorDate: Tue Apr  7 18:25:58 2020 +
Commit: Lars Wendler  gentoo  org>
CommitDate: Tue Apr  7 18:25:58 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=a13a78e0

media-libs/harfbuzz: Removed old

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Lars Wendler  gentoo.org>

 media-libs/harfbuzz/Manifest  |   1 -
 media-libs/harfbuzz/harfbuzz-2.6.1.ebuild | 115 --
 2 files changed, 116 deletions(-)

diff --git a/media-libs/harfbuzz/Manifest b/media-libs/harfbuzz/Manifest
index 9773b7afb4e..66b2d916e50 100644
--- a/media-libs/harfbuzz/Manifest
+++ b/media-libs/harfbuzz/Manifest
@@ -1,2 +1 @@
-DIST harfbuzz-2.6.1.tar.xz 5741372 BLAKE2B 
bb763eba23a37bd20d0ddb39824d5a0c655d6e098aea2e44b6943e7bd5cb1f9a5cd94e3de5520d962e3c476defac43af58f98d0a5b80e5c1506d00bc716ec876
 SHA512 
cea531ab9db0ae1b188ac56c3ea6e0344192c4321b97d4425f4a53e6bb34c88463a7453fd69fcadccb8574506c1fb5505422019e41a7938a04e7823e3f484c06
 DIST harfbuzz-2.6.4.tar.xz 5967468 BLAKE2B 
24d215324a408a724f47a901c4a56605144d15373518bd52643ece83705d0c63582a80635ecef6a6d8d2f5f39c750076d553fb39aaa8c0dd41702ee910c32f24
 SHA512 
d8664bb64fda11ff7646693070637e3827f8b3d1de50e11ecf108ce4d19c878b26b2ba4cff278da6e6cc0cb431e1630d9eaa7c32a9bebb9655a7aa8dabf7114f

diff --git a/media-libs/harfbuzz/harfbuzz-2.6.1.ebuild 
b/media-libs/harfbuzz/harfbuzz-2.6.1.ebuild
deleted file mode 100644
index ec55a0858a5..000
--- a/media-libs/harfbuzz/harfbuzz-2.6.1.ebuild
+++ /dev/null
@@ -1,115 +0,0 @@
-# Copyright 1999-2020 Gentoo Authors
-# Distributed under the terms of the GNU General Public License v2
-
-EAPI=7
-
-PYTHON_COMPAT=( python2_7 )
-
-inherit flag-o-matic libtool multilib-minimal python-any-r1 xdg-utils
-
-DESCRIPTION="An OpenType text shaping engine"
-HOMEPAGE="https://www.freedesktop.org/wiki/Software/HarfBuzz;
-
-if [[ ${PV} =  ]] ; then
-   EGIT_REPO_URI="https://anongit.freedesktop.org/git/harfbuzz.git;
-   inherit git-r3 autotools
-else
-   SRC_URI="https://www.freedesktop.org/software/${PN}/release/${P}.tar.xz;
-   KEYWORDS="~alpha amd64 arm arm64 hppa ~ia64 ~mips ppc ppc64 s390 sparc 
x86 ~amd64-linux ~x86-linux ~ppc-macos ~x64-macos ~x86-macos ~sparc-solaris 
~sparc64-solaris ~x64-solaris ~x86-solaris"
-fi
-
-LICENSE="Old-MIT ISC icu"
-SLOT="0/0.9.18" # 0.9.18 introduced the harfbuzz-icu split; bug #472416
-
-IUSE="+cairo debug +glib +graphite icu +introspection static-libs test 
+truetype"
-RESTRICT="!test? ( test )"
-REQUIRED_USE="introspection? ( glib )"
-
-RDEPEND="
-   cairo? ( x11-libs/cairo:= )
-   glib? ( >=dev-libs/glib-2.38:2[${MULTILIB_USEDEP}] )
-   graphite? ( >=media-gfx/graphite2-1.2.1:=[${MULTILIB_USEDEP}] )
-   icu? ( >=dev-libs/icu-51.2-r1:=[${MULTILIB_USEDEP}] )
-   introspection? ( >=dev-libs/gobject-introspection-1.34:= )
-   truetype? ( >=media-libs/freetype-2.5.0.1:2=[${MULTILIB_USEDEP}] )
-"
-DEPEND="${RDEPEND}
-   test? ( ${PYTHON_DEPS} )
-"
-BDEPEND="
-   dev-util/gtk-doc-am
-   virtual/pkgconfig
-"
-# eautoreconf requires gobject-introspection-common
-# ragel needed if regenerating *.hh files from *.rl
-if [[ ${PV} =  ]] ; then
-   DEPEND+="
-   >=dev-libs/gobject-introspection-common-1.34
-   dev-util/ragel
-   "
-fi
-
-PATCHES=(
-   "${FILESDIR}"/${P}-gcc-9.patch
-)
-
-pkg_setup() {
-   use test && python-any-r1_pkg_setup
-   if ! use debug ; then
-   append-cppflags -DHB_NDEBUG
-   fi
-}
-
-src_prepare() {
-   default
-
-   xdg_environment_reset
-
-   if [[ ${CHOST} == *-darwin* || ${CHOST} == *-solaris* ]] ; then
-   # on Darwin/Solaris we need to link with g++, like automake 
defaults
-   # to, but overridden by upstream because on Linux this is not
-   # necessary, bug #449126
-   sed -i \
-   -e 's/\/CXXLINK/' \
-   src/Makefile.am || die
-   sed -i \
-   -e '/libharfbuzz_la_LINK = /s/\/CXXLINK/' \
-   src/Makefile.in || die
-   sed -i \
-   -e '/AM_V_CCLD/s/\/CXXLINK/' \
-   test/api/Makefile.in || die
-   fi
-
-   [[ ${PV} ==  ]] && eautoreconf
-   elibtoolize # for Solaris
-
-   # bug 618772
-   append-cxxflags -std=c++14
-}
-
-multilib_src_configure() {
-   # harfbuzz-gobject only used for instrospection, bug #535852
-   local myeconfargs=(
-   --without-coretext
-   --without-fontconfig #609300
-   --without-uniscribe
-   $(use_enable static-libs static)
-   $(multilib_native_use_with cairo)
-   $(use_with glib)
-   $(use_with introspection gobject)
-   $(use_with graphite graphite2)
-   

[gentoo-commits] repo/gentoo:master commit in: net-fs/samba/

2020-04-07 Thread Lars Wendler
commit: 3ac048de94195e32eb515fc59322756998f59d91
Author: Lars Wendler  gentoo  org>
AuthorDate: Tue Apr  7 18:23:47 2020 +
Commit: Lars Wendler  gentoo  org>
CommitDate: Tue Apr  7 18:24:22 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=3ac048de

net-fs/samba: Bump to version 4.12.1

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Lars Wendler  gentoo.org>

 net-fs/samba/Manifest|   1 +
 net-fs/samba/samba-4.12.1.ebuild | 312 +++
 2 files changed, 313 insertions(+)

diff --git a/net-fs/samba/Manifest b/net-fs/samba/Manifest
index fb43e058142..f4c0f791d2b 100644
--- a/net-fs/samba/Manifest
+++ b/net-fs/samba/Manifest
@@ -1,3 +1,4 @@
 DIST samba-4.11.6.tar.gz 18541566 BLAKE2B 
2b4a40be7cec8a9706cbc344796885f59403aa11ca3d8a7dc40b3d287ec222c11d7395fd193c4b66c4116f1bffd869caf444a950d508f5a9a596db32553e1461
 SHA512 
3815080a1693c596a126371a5ea4e8534317a7266803c7de13a7e5b3ee9757dfbf13c0de20d498a6683d3aaf56941ed42f289e3c24f88713529a5f047a691af2
 DIST samba-4.11.7.tar.gz 18541292 BLAKE2B 
083ee2ebade2dd6267f8c53234bd98cc3325d28cf0a03fce2f45accfd36acfaaa9cdc82f326e913cfdbd585b0d705c71a95685ec37901e7d8a4d17cd2a04d3f2
 SHA512 
c728adbc9fd86f9b745f62d2f435d0fd5e8d1381725a657f8d14ec246d5c758c9eb92bd82c25b0c3f40ce4d10eaf5ce7792363b8a8c4df2e6c78c1458fef4f95
 DIST samba-4.12.0.tar.gz 18156651 BLAKE2B 
a02a5cdce9551743bfa88fe9e42ab2f2b6fc3ec96e933bcb92f994681b8dbbeef675f718e723f131c95252a51d964d141f5dda98529dc7779ba372fc6d0080c5
 SHA512 
d50be899675b8e3504311e73bb75fbb8264e918e0d1765239ecb5b14e15c0917565f8a9ce1877fb604151bf4f23dfc4c2f7f30a53c872681e3d2571d3ed5ef82
+DIST samba-4.12.1.tar.gz 18159628 BLAKE2B 
aff697383ed53f4e8d7506ca284d160e76747ea49849c32bfe712fff83cd1a66a835c8da4f325a78599e53dc29f59e626fc7b285c67c5364f180491c3ba62f7d
 SHA512 
2645f72dcc4718bd2e85af73a54b3e6d0ca9e11bd6991a47a6c17a8b89b69f294a0875ef9762dde28a25d1ff030e0e2d0e073a6993e2df0d6b17e75b72d1cd26

diff --git a/net-fs/samba/samba-4.12.1.ebuild b/net-fs/samba/samba-4.12.1.ebuild
new file mode 100644
index 000..c727b591ae9
--- /dev/null
+++ b/net-fs/samba/samba-4.12.1.ebuild
@@ -0,0 +1,312 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=6
+
+PYTHON_COMPAT=( python3_{6,7,8} )
+PYTHON_REQ_USE='threads(+),xml(+)'
+inherit python-single-r1 waf-utils multilib-minimal linux-info systemd pam
+
+MY_PV="${PV/_rc/rc}"
+MY_P="${PN}-${MY_PV}"
+
+SRC_PATH="stable"
+[[ ${PV} = *_rc* ]] && SRC_PATH="rc"
+
+SRC_URI="mirror://samba/${SRC_PATH}/${MY_P}.tar.gz"
+[[ ${PV} = *_rc* ]] || \
+KEYWORDS="~amd64 ~x86"
+
+DESCRIPTION="Samba Suite Version 4"
+HOMEPAGE="https://www.samba.org/;
+LICENSE="GPL-3"
+
+SLOT="0"
+
+IUSE="acl addc addns ads ceph client cluster cups debug dmapi fam gpg iprint
+json ldap pam profiling-data python quota selinux syslog system-heimdal
++system-mitkrb5 systemd test winbind zeroconf"
+
+MULTILIB_WRAPPED_HEADERS=(
+   /usr/include/samba-4.0/policy.h
+   /usr/include/samba-4.0/dcerpc_server.h
+   /usr/include/samba-4.0/ctdb.h
+   /usr/include/samba-4.0/ctdb_client.h
+   /usr/include/samba-4.0/ctdb_protocol.h
+   /usr/include/samba-4.0/ctdb_private.h
+   /usr/include/samba-4.0/ctdb_typesafe_cb.h
+   /usr/include/samba-4.0/ctdb_version.h
+)
+
+CDEPEND="
+   >=app-arch/libarchive-3.1.2[${MULTILIB_USEDEP}]
+   dev-lang/perl:=
+   dev-libs/icu:=[${MULTILIB_USEDEP}]
+   dev-libs/libbsd[${MULTILIB_USEDEP}]
+   dev-libs/libtasn1[${MULTILIB_USEDEP}]
+   dev-libs/popt[${MULTILIB_USEDEP}]
+   dev-perl/Parse-Yapp
+   >=net-libs/gnutls-3.4.7[${MULTILIB_USEDEP}]
+   net-libs/libnsl:=[${MULTILIB_USEDEP}]
+   sys-apps/dbus[${MULTILIB_USEDEP}]
+   sys-libs/e2fsprogs-libs[${MULTILIB_USEDEP}]
+   
>=sys-libs/ldb-2.1.1[ldap(+)?,python?,${PYTHON_SINGLE_USEDEP},${MULTILIB_USEDEP}]
+   
=sys-libs/talloc-2.3.1[python?,${PYTHON_SINGLE_USEDEP},${MULTILIB_USEDEP}]
+   >=sys-libs/tdb-1.4.3[python?,${PYTHON_SINGLE_USEDEP},${MULTILIB_USEDEP}]
+   
>=sys-libs/tevent-0.10.2[python?,${PYTHON_SINGLE_USEDEP},${MULTILIB_USEDEP}]
+   sys-libs/zlib[${MULTILIB_USEDEP}]
+   virtual/libiconv
+   pam? ( sys-libs/pam )
+   acl? ( virtual/acl )
+   $(python_gen_cond_dep "
+   dev-python/subunit[\${PYTHON_MULTI_USEDEP},${MULTILIB_USEDEP}]
+   addns? (
+   net-dns/bind-tools[gssapi]
+   dev-python/dnspython:=[\${PYTHON_MULTI_USEDEP}]
+   )
+   ")
+   ceph? ( sys-cluster/ceph )
+   cluster? (
+   net-libs/rpcsvc-proto
+   !dev-db/ctdb
+   )
+   cups? ( net-print/cups )
+   debug? ( dev-util/lttng-ust )
+   dmapi? ( sys-apps/dmapi )
+   fam? ( virtual/fam )
+   gpg? ( app-crypt/gpgme )
+   json? ( dev-libs/jansson )
+   ldap? ( net-nds/openldap[${MULTILIB_USEDEP}] 

[gentoo-commits] repo/gentoo:master commit in: net-fs/cifs-utils/, net-fs/cifs-utils/files/

2020-04-07 Thread Lars Wendler
commit: b58d5ee0855300ba790563f55b3d6f51aea44280
Author: Lars Wendler  gentoo  org>
AuthorDate: Tue Apr  7 18:18:07 2020 +
Commit: Lars Wendler  gentoo  org>
CommitDate: Tue Apr  7 18:24:21 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=b58d5ee0

net-fs/cifs-utils: Bump to version 6.10

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Lars Wendler  gentoo.org>

 net-fs/cifs-utils/Manifest |   1 +
 net-fs/cifs-utils/cifs-utils-6.10.ebuild   | 121 +
 .../files/cifs-utils-6.10-ln_in_destdir.patch  |  15 +++
 3 files changed, 137 insertions(+)

diff --git a/net-fs/cifs-utils/Manifest b/net-fs/cifs-utils/Manifest
index dbd5aeb88d8..a95c5f03d97 100644
--- a/net-fs/cifs-utils/Manifest
+++ b/net-fs/cifs-utils/Manifest
@@ -1,3 +1,4 @@
+DIST cifs-utils-6.10.tar.bz2 364221 BLAKE2B 
45b692fb85217a25b7042fbe7e40cc8c4fe0d6cc9c905acde2c6fc9c3048343064e376f47128bcacba88f745452148040ad3f5e8ca15e297531f0dc868e1b75b
 SHA512 
e19ca69b7948f01c1fd6a4ed069e00511588b903a5b8b0dc35ac1e00743170b9ca180b747c47d56cfacf273b296da21df60e1957404f26ebf2ba80bfa7e275cc
 DIST cifs-utils-6.7.tar.bz2 363647 BLAKE2B 
692c4b7de92c2cc5cb88591fb5b5b01ca7d925b105d10f7149e350d1b1661bb6447e71e0ca86095a9e294637d80126e54295413a685786b62c8e70cf26f893d0
 SHA512 
ee050a0eb4a72fbc8d773e86fbe6839ea2bf11cda5ebd071c8ead66e31b46d50ea4e1d1b26478373be53227cd60b32a90b65b5cb989b5a8237cddfc65bad8e5e
 DIST cifs-utils-6.8.tar.bz2 384426 BLAKE2B 
002518f44489aefc94c47a23438b176a4056ff4d995b3ed9f25a6c6c8d4c8d7437a3158d5c592d16cb6bfcd289b937d6ac1ef0573c346993d576a88aa1fcb118
 SHA512 
54a094f78c9e07acc997adfe0c8d4c2fb8e15c18adcc1805450e2180f8539aaec8619e781e985b289e097932637e2de3e6815e32f59ec2fc06cfc3762b832e13
 DIST cifs-utils-6.9.tar.bz2 400430 BLAKE2B 
fc8cc55fae54d84fc1f1d4a14a9d666d87a3da78d1502f0d72ac9cb44ff1424ca2c5b15b0be510579d4c9f5181980627efedd00e0e5cfb1b3e47188ba307ad28
 SHA512 
b92e4e39eeed1032bb175659296cde034703fb3ca63aae00419d46a33dadf821fedaf03734128112c164c84bcbb48d92d03cdc275c4a7cba26f984aeca40a40a

diff --git a/net-fs/cifs-utils/cifs-utils-6.10.ebuild 
b/net-fs/cifs-utils/cifs-utils-6.10.ebuild
new file mode 100644
index 000..63cd03fbe6d
--- /dev/null
+++ b/net-fs/cifs-utils/cifs-utils-6.10.ebuild
@@ -0,0 +1,121 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit autotools linux-info multilib pam
+
+DESCRIPTION="Tools for Managing Linux CIFS Client Filesystems"
+HOMEPAGE="https://wiki.samba.org/index.php/LinuxCIFS_utils;
+SRC_URI="https://ftp.samba.org/pub/linux-cifs/${PN}/${P}.tar.bz2;
+
+LICENSE="GPL-3"
+SLOT="0"
+KEYWORDS="~alpha ~amd64 ~arm ~arm64 ~hppa ~ia64 ~mips ~ppc ~ppc64 ~s390 ~sparc 
~x86 ~x86-linux"
+IUSE="+acl +ads +caps creds pam"
+
+RDEPEND="
+   !net-fs/mount-cifs
+   !https://bugs.gentoo.org/612584
+   eapply "${FILESDIR}/${PN}-6.7-heimdal.patch"
+   fi
+
+   eautoreconf
+}
+
+src_configure() {
+   local myeconfargs=(
+   --enable-smbinfo
+   $(use_enable acl cifsacl cifsidmap)
+   $(use_enable ads cifsupcall)
+   $(use_with caps libcap)
+   $(use_enable creds cifscreds)
+   $(use_enable pam)
+   $(use_with pam pamdir $(getpam_mod_dir))
+   )
+   ROOTSBINDIR="${EPREFIX}"/sbin \
+   econf "${myeconfargs[@]}"
+}
+
+src_install() {
+   default
+
+   # remove empty directories
+   find "${ED}" -type d -empty -delete || die
+
+   if use acl ; then
+   dodir /etc/cifs-utils
+   dosym ../../usr/$(get_libdir)/cifs-utils/idmapwb.so \
+   /etc/cifs-utils/idmap-plugin
+   dodir /etc/request-key.d
+   echo 'create cifs.idmap * * /usr/sbin/cifs.idmap %k' \
+   > "${ED}/etc/request-key.d/cifs.idmap.conf"
+   fi
+
+   if use ads ; then
+   dodir /etc/request-key.d
+   echo 'create dns_resolver * * /usr/sbin/cifs.upcall %k' \
+   > "${ED}/etc/request-key.d/cifs.upcall.conf"
+   echo 'create cifs.spnego * * /usr/sbin/cifs.upcall %k' \
+   > "${ED}/etc/request-key.d/cifs.spnego.conf"
+   fi
+}
+
+pkg_postinst() {
+   # Inform about set-user-ID bit of mount.cifs
+   ewarn "setuid use flag was dropped due to multiple security 
implications"
+   ewarn "such as CVE-2009-2948, CVE-2011-3585 and CVE-2012-1586"
+   ewarn "You are free to set setuid flags by yourself"
+
+   # Inform about upcall usage
+   if use acl ; then
+   einfo "The cifs.idmap utility has been enabled by creating the"
+   einfo "configuration file /etc/request-key.d/cifs.idmap.conf"
+   einfo "This enables you to get and set CIFS acls."
+   fi
+
+   if use ads ; then
+   einfo "The cifs.upcall 

[gentoo-commits] repo/gentoo:master commit in: net-fs/cifs-utils/files/, net-fs/cifs-utils/

2020-04-07 Thread Lars Wendler
commit: 2b49e9ce6a55e55611420846b7e48ccb5ef13427
Author: Lars Wendler  gentoo  org>
AuthorDate: Tue Apr  7 18:22:14 2020 +
Commit: Lars Wendler  gentoo  org>
CommitDate: Tue Apr  7 18:24:22 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=2b49e9ce

net-fs/cifs-utils: Removed old

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Lars Wendler  gentoo.org>

 net-fs/cifs-utils/Manifest |   2 -
 net-fs/cifs-utils/cifs-utils-6.7.ebuild| 123 -
 net-fs/cifs-utils/cifs-utils-6.8-r1.ebuild | 119 
 .../cifs-utils/files/cifs-utils-6.7-talloc.patch   |  29 -
 net-fs/cifs-utils/metadata.xml |  12 +-
 5 files changed, 9 insertions(+), 276 deletions(-)

diff --git a/net-fs/cifs-utils/Manifest b/net-fs/cifs-utils/Manifest
index a95c5f03d97..6571c0d3ac2 100644
--- a/net-fs/cifs-utils/Manifest
+++ b/net-fs/cifs-utils/Manifest
@@ -1,4 +1,2 @@
 DIST cifs-utils-6.10.tar.bz2 364221 BLAKE2B 
45b692fb85217a25b7042fbe7e40cc8c4fe0d6cc9c905acde2c6fc9c3048343064e376f47128bcacba88f745452148040ad3f5e8ca15e297531f0dc868e1b75b
 SHA512 
e19ca69b7948f01c1fd6a4ed069e00511588b903a5b8b0dc35ac1e00743170b9ca180b747c47d56cfacf273b296da21df60e1957404f26ebf2ba80bfa7e275cc
-DIST cifs-utils-6.7.tar.bz2 363647 BLAKE2B 
692c4b7de92c2cc5cb88591fb5b5b01ca7d925b105d10f7149e350d1b1661bb6447e71e0ca86095a9e294637d80126e54295413a685786b62c8e70cf26f893d0
 SHA512 
ee050a0eb4a72fbc8d773e86fbe6839ea2bf11cda5ebd071c8ead66e31b46d50ea4e1d1b26478373be53227cd60b32a90b65b5cb989b5a8237cddfc65bad8e5e
-DIST cifs-utils-6.8.tar.bz2 384426 BLAKE2B 
002518f44489aefc94c47a23438b176a4056ff4d995b3ed9f25a6c6c8d4c8d7437a3158d5c592d16cb6bfcd289b937d6ac1ef0573c346993d576a88aa1fcb118
 SHA512 
54a094f78c9e07acc997adfe0c8d4c2fb8e15c18adcc1805450e2180f8539aaec8619e781e985b289e097932637e2de3e6815e32f59ec2fc06cfc3762b832e13
 DIST cifs-utils-6.9.tar.bz2 400430 BLAKE2B 
fc8cc55fae54d84fc1f1d4a14a9d666d87a3da78d1502f0d72ac9cb44ff1424ca2c5b15b0be510579d4c9f5181980627efedd00e0e5cfb1b3e47188ba307ad28
 SHA512 
b92e4e39eeed1032bb175659296cde034703fb3ca63aae00419d46a33dadf821fedaf03734128112c164c84bcbb48d92d03cdc275c4a7cba26f984aeca40a40a

diff --git a/net-fs/cifs-utils/cifs-utils-6.7.ebuild 
b/net-fs/cifs-utils/cifs-utils-6.7.ebuild
deleted file mode 100644
index b6230ed3b39..000
--- a/net-fs/cifs-utils/cifs-utils-6.7.ebuild
+++ /dev/null
@@ -1,123 +0,0 @@
-# Copyright 1999-2020 Gentoo Authors
-# Distributed under the terms of the GNU General Public License v2
-
-EAPI=6
-
-inherit autotools eutils linux-info multilib pam
-
-DESCRIPTION="Tools for Managing Linux CIFS Client Filesystems"
-HOMEPAGE="https://wiki.samba.org/index.php/LinuxCIFS_utils;
-SRC_URI="https://ftp.samba.org/pub/linux-cifs/${PN}/${P}.tar.bz2;
-
-LICENSE="GPL-3"
-SLOT="0"
-KEYWORDS="~alpha amd64 arm ~arm64 hppa ~ia64 ~mips ppc ppc64 ~s390 sparc x86 
~x86-linux"
-IUSE="+acl +ads +caps +caps-ng creds pam"
-
-RDEPEND="
-   !net-fs/mount-cifs
-   !https://bugs.gentoo.org/612584
-   eapply "${FILESDIR}/${PN}-6.7-heimdal.patch"
-   fi
-
-   eautoreconf
-}
-
-src_configure() {
-   ROOTSBINDIR="${EPREFIX}"/sbin \
-   econf \
-   $(use_enable acl cifsacl cifsidmap) \
-   $(use_enable ads cifsupcall) \
-   $(use caps && use_with !caps-ng libcap || echo 
--without-libcap) \
-   $(use caps && use_with caps-ng libcap-ng || echo 
--without-libcap-ng) \
-   $(use_enable creds cifscreds) \
-   $(use_enable pam) \
-   $(use_with pam pamdir $(getpam_mod_dir))
-}
-
-src_install() {
-   default
-
-   # remove empty directories
-   find "${ED}" -type d -print0 | xargs --null rmdir \
-   --ignore-fail-on-non-empty &>/dev/null
-
-   if use acl ; then
-   dodir /etc/cifs-utils
-   dosym /usr/$(get_libdir)/cifs-utils/idmapwb.so \
-   /etc/cifs-utils/idmap-plugin
-   dodir /etc/request-key.d
-   echo 'create cifs.idmap * * /usr/sbin/cifs.idmap %k' \
-   > "${ED}/etc/request-key.d/cifs.idmap.conf"
-   fi
-
-   if use ads ; then
-   dodir /etc/request-key.d
-   echo 'create dns_resolver * * /usr/sbin/cifs.upcall %k' \
-   > "${ED}/etc/request-key.d/cifs.upcall.conf"
-   echo 'create cifs.spnego * * /usr/sbin/cifs.upcall %k' \
-   > "${ED}/etc/request-key.d/cifs.spnego.conf"
-   fi
-}
-
-pkg_postinst() {
-   # Inform about set-user-ID bit of mount.cifs
-   ewarn "setuid use flag was dropped due to multiple security 
implications"
-   ewarn "such as CVE-2009-2948, CVE-2011-3585 and CVE-2012-1586"
-   ewarn "You are free to set setuid flags by yourself"
-
-   # Inform about upcall usage
-   if use acl ; then
-   einfo "The cifs.idmap 

[gentoo-commits] repo/gentoo:master commit in: sys-apps/util-linux/

2020-04-07 Thread Lars Wendler
commit: e602e8acfdc30076f31c13eebbcbb1f8229200e9
Author: Lars Wendler  gentoo  org>
AuthorDate: Mon Apr  6 17:47:32 2020 +
Commit: Lars Wendler  gentoo  org>
CommitDate: Tue Apr  7 18:24:21 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=e602e8ac

sys-apps/util-linux: Removed old

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Lars Wendler  gentoo.org>

 sys-apps/util-linux/Manifest   |   1 -
 sys-apps/util-linux/util-linux-2.35.ebuild | 308 -
 2 files changed, 309 deletions(-)

diff --git a/sys-apps/util-linux/Manifest b/sys-apps/util-linux/Manifest
index 8e68a59f4e2..0114a27eef6 100644
--- a/sys-apps/util-linux/Manifest
+++ b/sys-apps/util-linux/Manifest
@@ -1,4 +1,3 @@
 DIST util-linux-2.33.2.tar.xz 4707024 BLAKE2B 
fdeed0a236edd26d268bccca8cde2cf1b7ecbff521ede9fa26ea22c8e5cdfc380a416a168789504b303f1b569d163e41f6630ee28829be7f2b2129fa14c4fffa
 SHA512 
ac88790a0272366b384b54df19cb28318014d98819d5d96aa05528ff17ab57a8c66d012a2f1b59caca4c5d4ea669e8c041e1123517c1f1c2d9960ef701aaf749
 DIST util-linux-2.34.tar.xz 4974812 BLAKE2B 
d26b2f74d490eaee0a40d4c75a1a351ba165b4a52f9bbf6cf9d1afd7ae1382a3a3dfe41180584e97e9aaad6950f604cad928f30747590e3e1e669c8797689758
 SHA512 
2d0b76f63d32e7afb7acf61a83fabbfd58baa34ab78b3a331ce87f9c676a5fd71c56a493ded95039540d2c46b6048caaa38d7fb4491eb3d52d7b09dc54655cd7
 DIST util-linux-2.35.1.tar.xz 5138360 BLAKE2B 
08c16d4d9fd670b62c2d664feda2cfa53d0cecc36bbaa2c3ed5960bf70f905f11caa7a904c63f36e12b472f10b8e781351cca0cf2f858c2b66e4fd0204b1c456
 SHA512 
6e27e08bfc02378970f015decfea5a52d6c342c4c8f4ac48dd07d248485eb797e506d91d290dbbca344c3e5cfe1fc150db80a23d510367427232f5abeabe591a
-DIST util-linux-2.35.tar.xz 5137796 BLAKE2B 
fbd3124284d50e1dc3fd158f77969057c628e111ee489a920896cfbd93186de4cf1ea97f41854171f824e4b3042968d860827557a8d46aeadcfe5ef976e71222
 SHA512 
c95d26b9037d6b877a247e6aeb58d17aa80f7e1bd6b523a4e0fde559fe07b3d924ece6d373300fefb65d1f206b3f990aeddb3a03605040e72ce6d6ee88591021

diff --git a/sys-apps/util-linux/util-linux-2.35.ebuild 
b/sys-apps/util-linux/util-linux-2.35.ebuild
deleted file mode 100644
index 4505fc5a4b9..000
--- a/sys-apps/util-linux/util-linux-2.35.ebuild
+++ /dev/null
@@ -1,308 +0,0 @@
-# Copyright 1999-2020 Gentoo Authors
-# Distributed under the terms of the GNU General Public License v2
-
-EAPI=7
-
-PYTHON_COMPAT=( python3_{6,7,8} )
-
-inherit toolchain-funcs libtool flag-o-matic bash-completion-r1 usr-ldscript \
-   pam python-r1 multilib-minimal multiprocessing systemd
-
-MY_PV="${PV/_/-}"
-MY_P="${PN}-${MY_PV}"
-
-if [[ ${PV} ==  ]] ; then
-   inherit git-r3 autotools
-   
EGIT_REPO_URI="https://git.kernel.org/pub/scm/utils/util-linux/util-linux.git;
-else
-   [[ "${PV}" = *_rc* ]] || \
-   KEYWORDS="~alpha ~amd64 ~arm ~arm64 ~hppa ~ia64 ~m68k ~mips ~ppc ~ppc64 
~s390 ~sparc ~x86 ~amd64-linux ~x86-linux"
-   
SRC_URI="https://www.kernel.org/pub/linux/utils/util-linux/v${PV:0:4}/${MY_P}.tar.xz;
-fi
-
-DESCRIPTION="Various useful Linux utilities"
-HOMEPAGE="https://www.kernel.org/pub/linux/utils/util-linux/ 
https://github.com/karelzak/util-linux;
-
-LICENSE="GPL-2 LGPL-2.1 BSD-4 MIT public-domain"
-SLOT="0"
-IUSE="build caps +cramfs cryptsetup fdformat hardlink kill +logger ncurses nls 
pam python +readline selinux slang static-libs su +suid systemd test 
tty-helpers udev unicode userland_GNU"
-
-# Most lib deps here are related to programs rather than our libs,
-# so we rarely need to specify ${MULTILIB_USEDEP}.
-RDEPEND="
-   caps? ( sys-libs/libcap-ng )
-   cramfs? ( sys-libs/zlib:= )
-   cryptsetup? ( sys-fs/cryptsetup )
-   ncurses? ( >=sys-libs/ncurses-5.2-r2:0=[unicode?] )
-   nls? ( virtual/libintl[${MULTILIB_USEDEP}] )
-   pam? ( sys-libs/pam )
-   python? ( ${PYTHON_DEPS} )
-   readline? ( sys-libs/readline:0= )
-   selinux? ( >=sys-libs/libselinux-2.2.2-r4[${MULTILIB_USEDEP}] )
-   slang? ( sys-libs/slang )
-   !build? ( systemd? ( sys-apps/systemd ) )
-   udev? ( virtual/libudev:= )"
-BDEPEND="
-   virtual/pkgconfig
-   nls? ( sys-devel/gettext )
-   test? ( sys-devel/bc )
-"
-DEPEND="
-   ${RDEPEND}
-   virtual/os-headers
-"
-RDEPEND+="
-   hardlink? ( !app-arch/hardlink )
-   logger? ( !>=app-admin/sysklogd-2.0[logger] )
-   kill? (
-   !sys-apps/coreutils[kill]
-   !sys-process/procps[kill]
-   )
-   su? (
-   !=sys-apps/shadow-4.7-r2[su]
-   )
-   !net-wireless/rfkill
-   !sys-process/schedutils
-   !sys-apps/setarch
-   ! "${T}"/fallocate.${ABI}.c
-   #define _GNU_SOURCE
-   #include 
-   main() { return fallocate(0, 0, 0, 0); }
-   EOF
-   append-lfs-flags
-   $(tc-getCC) ${CFLAGS} ${CPPFLAGS} ${LDFLAGS} "${T}"/fallocate.${ABI}.c 
-o /dev/null >/dev/null 2>&1 \
-   || export ac_cv_func_fallocate=no
- 

[gentoo-commits] repo/gentoo:master commit in: net-dns/pdns/

2020-04-07 Thread Sven Wegener
commit: f89bebf411e0247c9fdfe10432bf942f1c0ed646
Author: Sven Wegener  gentoo  org>
AuthorDate: Tue Apr  7 18:21:09 2020 +
Commit: Sven Wegener  gentoo  org>
CommitDate: Tue Apr  7 18:21:43 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=f89bebf4

net-dns/pdns: Version bump to 4.3.0

Package-Manager: Portage-2.3.89, Repoman-2.3.20
Signed-off-by: Sven Wegener  gentoo.org>

 net-dns/pdns/Manifest | 2 +-
 net-dns/pdns/{pdns-4.3.0_rc2.ebuild => pdns-4.3.0.ebuild} | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)

diff --git a/net-dns/pdns/Manifest b/net-dns/pdns/Manifest
index ba541a6469e..ef27f7bcb00 100644
--- a/net-dns/pdns/Manifest
+++ b/net-dns/pdns/Manifest
@@ -1,4 +1,4 @@
 DIST pdns-4.1.13.tar.bz2 1117990 BLAKE2B 
95fa26d872fe138d1cde7e586881010dd27211c4186d0a99693d2fd90bdc3fd939da09805898d469daec6fe8c3493166346cf18b528760f3b25274fe10f45ad2
 SHA512 
94d80b1c6b78e93dd856631d391225c521485c3fb6b4123b28f9f58e178a7f6eb03f24189eaa261873e7e29962761b513c1fcf092101d68ad81dac73249a54d4
 DIST pdns-4.2.0.tar.bz2 1249282 BLAKE2B 
56b3639004abd05ab9df4541cc46f155ce76426b35a29d9a4cedd16428c5852bf9306e14b77440b8239e823cb0603b4747a8ae7729f964f415a529f17706eb1f
 SHA512 
ee67c132458e539d522aaa5835237dc64d92ad546f51e0ef86366964f7105631f2bd1e6c5d19d85466d95e1982f6410aeb14932c265fddfd301e403e76542624
 DIST pdns-4.2.1.tar.bz2 1252829 BLAKE2B 
e5cfcdd0c3011fe43e5abe52e5308b5e6346d186c5d5046c862468ecf810db7e5ab64bd36a9c62f251fbf63948572c5193ed354b8e98d647111e9373578c54ef
 SHA512 
40b5533c755d7c0d41cfb273b704a45a3006dafc98c79bf41cae43d9e2d03bbd7a663996a7f209c390a89c5f7161f2f6246389beef18fbac48e95907e1b7936a
-DIST pdns-4.3.0-rc2.tar.bz2 1211130 BLAKE2B 
48d1c1fb67031a42cbcb52badf914bd7e3e642d15866af55bebcb7ee65fadff5a5e058a5888b112423c68a83207e304eab33d9f45e3e3d5e265a88f18f0980ee
 SHA512 
c1ec2366345ac8d2d19768abbfa4d0c0308df121f06deeb7d84b5d6abb702d877ad40ade37f13cce3e3f08e6a70069380dcf6de3c400a2c492182bbcbe1b4569
+DIST pdns-4.3.0.tar.bz2 1211536 BLAKE2B 
3291597c4f0c39e23f793b128ef26b1ce3dc77640ddf6979242ab291b0e2780ae5c19b18591ea90f5282810044959feca265a245e27eca1f2ebacbdeeb8a3785
 SHA512 
0734dbfb83a2e5080dc54cfc016ceb3e1f7e15a2de2f33392b2f3c995357fa97f9e87ff21e969f148c3e881165471d3058eb2b9cf632117ebce0d7818e025fe2

diff --git a/net-dns/pdns/pdns-4.3.0_rc2.ebuild b/net-dns/pdns/pdns-4.3.0.ebuild
similarity index 99%
rename from net-dns/pdns/pdns-4.3.0_rc2.ebuild
rename to net-dns/pdns/pdns-4.3.0.ebuild
index ae487fd7f0d..97e6ee4740a 100644
--- a/net-dns/pdns/pdns-4.3.0_rc2.ebuild
+++ b/net-dns/pdns/pdns-4.3.0.ebuild
@@ -11,7 +11,7 @@ 
SRC_URI="https://downloads.powerdns.com/releases/${P/_/-}.tar.bz2;
 
 LICENSE="GPL-2"
 SLOT="0"
-KEYWORDS="" # ~amd64 ~x86
+KEYWORDS="~amd64 ~x86"
 
 # other possible flags:
 # db2: we lack the dep



[gentoo-commits] repo/gentoo:master commit in: net-misc/iputils/, net-misc/iputils/files/

2020-04-07 Thread Thomas Deutschmann
commit: 23a95c6869f3abe76afd4197e4b7f92d25048861
Author: Thomas Deutschmann  gentoo  org>
AuthorDate: Tue Apr  7 18:04:59 2020 +
Commit: Thomas Deutschmann  gentoo  org>
CommitDate: Tue Apr  7 18:09:23 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=23a95c68

net-misc/iputils: fix arping

Closes: https://bugs.gentoo.org/692982
Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Thomas Deutschmann  gentoo.org>

 ...rt-partially-fix-sent-vs-received-package.patch |  34 
 net-misc/iputils/iputils-20190709-r1.ebuild| 201 +
 2 files changed, 235 insertions(+)

diff --git 
a/net-misc/iputils/files/iputils-20190709-arping-revert-partially-fix-sent-vs-received-package.patch
 
b/net-misc/iputils/files/iputils-20190709-arping-revert-partially-fix-sent-vs-received-package.patch
new file mode 100644
index 000..715ed45041b
--- /dev/null
+++ 
b/net-misc/iputils/files/iputils-20190709-arping-revert-partially-fix-sent-vs-received-package.patch
@@ -0,0 +1,34 @@
+From 18f14be80466ddc8fb17a400be82764a779c8dcd Mon Sep 17 00:00:00 2001
+From: Sami Kerola 
+Date: Wed, 31 Jul 2019 21:28:12 +0100
+Subject: [PATCH] arping: revert partially - fix sent vs received packages
+ return value
+
+Commit 84ca65ca980315c73f929fed8b6f16bbd698c3a0 caused regression.  The
+arping -D needs return value evaluation that was the earlier default, in
+other cases the new return value should be correct.
+
+Addresses: https://github.com/iputils/iputils/issues/209
+See-also: https://github.com/void-linux/void-packages/issues/13304
+Signed-off-by: Sami Kerola 
+---
+ arping.c | 6 +-
+ 1 file changed, 5 insertions(+), 1 deletion(-)
+
+diff --git a/arping.c b/arping.c
+index 77c9c56..2c87c15 100644
+--- a/arping.c
 b/arping.c
+@@ -792,7 +792,11 @@ static int event_loop(struct run_state *ctl)
+   close(tfd);
+   freeifaddrs(ctl->ifa0);
+   rc |= finish(ctl);
+-  rc |= (ctl->sent != ctl->received);
++  if (ctl->dad && ctl->quit_on_reply)
++  /* Duplicate address detection mode return value */
++  rc |= !(ctl->brd_sent != ctl->received);
++  else
++  rc |= (ctl->sent != ctl->received);
+   return rc;
+ }
+ 

diff --git a/net-misc/iputils/iputils-20190709-r1.ebuild 
b/net-misc/iputils/iputils-20190709-r1.ebuild
new file mode 100644
index 000..52bdec97980
--- /dev/null
+++ b/net-misc/iputils/iputils-20190709-r1.ebuild
@@ -0,0 +1,201 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+# For released versions, we precompile the man/html pages and store
+# them in a tarball on our mirrors.  This avoids ugly issues while
+# building stages, and reduces depedencies.
+# To regenerate man/html pages emerge iputils-[doc] with
+# EGIT_COMMIT set to release tag and tar ${S}/doc folder.
+
+EAPI="7"
+
+PLOCALES="ja"
+
+inherit fcaps flag-o-matic l10n meson systemd toolchain-funcs
+
+if [[ ${PV} == "" ]] ; then
+   EGIT_REPO_URI="https://github.com/iputils/iputils.git;
+   inherit git-r3
+else
+   SRC_URI="https://github.com/iputils/iputils/archive/s${PV}.tar.gz -> 
${P}.tar.gz
+   
https://dev.gentoo.org/~whissi/dist/iputils/${PN}-manpages-${PV}.tar.xz;
+   KEYWORDS="~alpha ~amd64 ~arm ~arm64 ~hppa ~ia64 ~m68k ~mips ~ppc ~ppc64 
~riscv ~s390 ~sparc ~x86 ~ppc-aix ~amd64-linux ~x86-linux"
+fi
+
+DESCRIPTION="Network monitoring tools including ping and ping6"
+HOMEPAGE="https://wiki.linuxfoundation.org/networking/iputils;
+
+LICENSE="BSD GPL-2+ rdisc"
+SLOT="0"
+IUSE="+arping caps clockdiff doc gcrypt idn ipv6 libressl nettle nls rarpd 
rdisc SECURITY_HAZARD ssl static tftpd tracepath traceroute6"
+
+BDEPEND="virtual/pkgconfig"
+
+LIB_DEPEND="
+   caps? ( sys-libs/libcap[static-libs(+)] )
+   idn? ( net-dns/libidn2:=[static-libs(+)] )
+   ipv6? (
+   ssl? (
+   gcrypt? ( dev-libs/libgcrypt:0=[static-libs(+)] )
+   !gcrypt? (
+   nettle? ( dev-libs/nettle[static-libs(+)] )
+   !nettle? (
+   libressl? ( 
dev-libs/libressl:0=[static-libs(+)] )
+   !libressl? ( 
dev-libs/openssl:0=[static-libs(+)] )
+   )
+   )
+   )
+   )
+   nls? ( sys-devel/gettext[static-libs(+)] )
+"
+
+RDEPEND="
+   arping? ( !net-misc/arping )
+   rarpd? ( !net-misc/rarpd )
+   traceroute6? ( !net-analyzer/traceroute )
+   !static? ( ${LIB_DEPEND//\[static-libs(+)]} )
+"
+
+DEPEND="
+   ${RDEPEND}
+   virtual/os-headers
+   static? ( ${LIB_DEPEND} )
+"
+
+if [[ ${PV} == "" ]] ; then
+   DEPEND+="
+   app-text/docbook-xml-dtd:4.2
+   app-text/docbook-xml-dtd:4.5
+   app-text/docbook-xsl-ns-stylesheets

[gentoo-commits] repo/gentoo:master commit in: net-misc/iputils/, net-misc/iputils/files/

2020-04-07 Thread Thomas Deutschmann
commit: 865c1a561c7eaabd160cd1d7b0aef09bfbcdb327
Author: Thomas Deutschmann  gentoo  org>
AuthorDate: Tue Apr  7 18:09:06 2020 +
Commit: Thomas Deutschmann  gentoo  org>
CommitDate: Tue Apr  7 18:09:24 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=865c1a56

net-misc/iputils: add some more patches for ping

- ping: try next addrinfo on connect failure
- ping: fix main loop over multiple addrinfo results

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Thomas Deutschmann  gentoo.org>

 ...-main-loop-over-multiple-addrinfo-results.patch |  86 ++
 ...ping-try-next-addrinfo-on-connect-failure.patch | 190 +
 net-misc/iputils/iputils-20190709-r1.ebuild|   2 +
 3 files changed, 278 insertions(+)

diff --git 
a/net-misc/iputils/files/iputils-20190709-ping-fix-main-loop-over-multiple-addrinfo-results.patch
 
b/net-misc/iputils/files/iputils-20190709-ping-fix-main-loop-over-multiple-addrinfo-results.patch
new file mode 100644
index 000..9814707d723
--- /dev/null
+++ 
b/net-misc/iputils/files/iputils-20190709-ping-fix-main-loop-over-multiple-addrinfo-results.patch
@@ -0,0 +1,86 @@
+From: Benjamin Poirier 
+Date: Thu, 26 Dec 2019 10:44:03 +0900
+Subject: ping: fix main loop over multiple addrinfo results
+
+Despite what the log of commit f68eec0eafad ("ping: perform dual-stack ping
+by default") says, main() was not designed to loop over multiple addresses
+returned by getaddrinfo().  This is apparent because until commit
+db11bc96a68c ("ping: make command to return from main()"), ping{4,6}_run()
+never returned (they always exited).  After commit db11bc96a68c, we
+encounter unexpected situations if getaddrinfo returns multiple results and
+ping{4,6}_run() return != 0.
+
+For example (notice echo reply is not received):
+
+root@vsid:/src/iputils# ./builddir/ping/ping -w1 google.com
+PING google.com(nrt12s22-in-x0e.1e100.net (2404:6800:4004:80c::200e)) 56 
data bytes
+
+--- google.com ping statistics ---
+1 packets transmitted, 0 received, 100% packet loss, time 0ms
+
+PING  (216.58.197.142) 56(84) bytes of data.
+
+---  ping statistics ---
+1 packets transmitted, 0 received, 100% packet loss, time -1002ms
+
+root@vsid:/src/iputils#
+
+Establish the following convention:
+
+* return value >= 0 -> exit with this code (same behavior as before commit
+  db11bc96a68c)
+
+* return value < 0 -> go on to next addrinfo result
+
+The second case will be used in the following patch.
+
+Fixes: db11bc96a68c ("ping: make command to return from main()")
+Signed-off-by: Benjamin Poirier 
+Origin: 
https://github.com/iputils/iputils/commit/c249e48bb865e731896b7d8ceaf4bca7d28768b6
+Bug-Debian: https://bugs.debian.org/947921
+See-also: https://github.com/iputils/iputils/pull/244
+---
+ ping.c | 6 +-
+ ping6_common.c | 1 +
+ 2 files changed, 6 insertions(+), 1 deletion(-)
+
+diff --git a/ping.c b/ping.c
+index 34653be..ae687b4 100644
+--- a/ping.c
 b/ping.c
+@@ -495,8 +495,11 @@ main(int argc, char **argv)
+   error(2, 0, _("unknown protocol family: %d"), 
ai->ai_family);
+   }
+ 
+-  if (ret_val == 0)
++  if (ret_val >= 0)
+   break;
++  /* ret_val < 0 means to go on to next addrinfo result, there
++   * better be one. */
++  assert(ai->ai_next);
+   }
+ 
+   freeaddrinfo(result);
+@@ -504,6 +507,7 @@ main(int argc, char **argv)
+   return ret_val;
+ }
+ 
++/* return >= 0: exit with this code, < 0: go on to next addrinfo result */
+ int ping4_run(int argc, char **argv, struct addrinfo *ai, socket_st *sock)
+ {
+   static const struct addrinfo hints = {
+diff --git a/ping6_common.c b/ping6_common.c
+index 6cc5404..731dc6d 100644
+--- a/ping6_common.c
 b/ping6_common.c
+@@ -551,6 +551,7 @@ int niquery_option_handler(const char *opt_arg)
+   return ret;
+ }
+ 
++/* return >= 0: exit with this code, < 0: go on to next addrinfo result */
+ int ping6_run(int argc, char **argv, struct addrinfo *ai, struct socket_st 
*sock)
+ {
+   static const struct addrinfo hints = {
+-- 
+2.25.0.rc2
+

diff --git 
a/net-misc/iputils/files/iputils-20190709-ping-try-next-addrinfo-on-connect-failure.patch
 
b/net-misc/iputils/files/iputils-20190709-ping-try-next-addrinfo-on-connect-failure.patch
new file mode 100644
index 000..a308fb7c9f6
--- /dev/null
+++ 
b/net-misc/iputils/files/iputils-20190709-ping-try-next-addrinfo-on-connect-failure.patch
@@ -0,0 +1,190 @@
+From: Benjamin Poirier 
+Date: Wed, 25 Dec 2019 13:33:12 +0900
+Subject: ping: try next addrinfo on connect failure
+
+On hosts that have routing rules matching on the outgoing interface [1],
+getaddrinfo() may return results sorted in a suboptimal order because it is
+not aware of the network interface passed to ping via the "-I" option.  In
+particular, address reachability detection may fail and 

[gentoo-commits] proj/catalyst:master commit in: targets/support/

2020-04-07 Thread Matt Turner
commit: 9ae5e17abc68907a0c8d75e16c29a84bb48c5e61
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 17:24:38 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 17:25:12 2020 +
URL:https://gitweb.gentoo.org/proj/catalyst.git/commit/?id=9ae5e17a

targets: Just make directory; don't bother checking

Signed-off-by: Matt Turner  gentoo.org>

 targets/support/bootloader-setup.sh | 3 +--
 1 file changed, 1 insertion(+), 2 deletions(-)

diff --git a/targets/support/bootloader-setup.sh 
b/targets/support/bootloader-setup.sh
index 2c69419d..c52e0907 100755
--- a/targets/support/bootloader-setup.sh
+++ b/targets/support/bootloader-setup.sh
@@ -233,8 +233,7 @@ case ${clst_hostarch} in
# GRUB2
if [ -d $1/grub ] || [ -f "$1/boot/EFI/BOOT/BOOTX64.EFI" ]
then
-   #the grub dir may not exist, better safe than sorry
-   [ -d "$1/grub" ] || mkdir -p "$1/grub"
+   mkdir -p "$1/grub"
 
iacfg=$1/grub/grub.cfg
echo 'set default=0' > ${iacfg}



[gentoo-commits] proj/catalyst:master commit in: targets/support/

2020-04-07 Thread Matt Turner
commit: e41b9e40c8d20fab3be2b9a1c071cefbf37341c0
Author: Matt Turner  gentoo  org>
AuthorDate: Tue Apr  7 17:24:00 2020 +
Commit: Matt Turner  gentoo  org>
CommitDate: Tue Apr  7 17:25:12 2020 +
URL:https://gitweb.gentoo.org/proj/catalyst.git/commit/?id=e41b9e40

targets: Fix copy-n-paste mistake

Fixes: b28b3ce7a4ac (targets: Use mkdir -p)
Signed-off-by: Matt Turner  gentoo.org>

 targets/support/bootloader-setup.sh | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/targets/support/bootloader-setup.sh 
b/targets/support/bootloader-setup.sh
index db5860d5..2c69419d 100755
--- a/targets/support/bootloader-setup.sh
+++ b/targets/support/bootloader-setup.sh
@@ -267,7 +267,7 @@ case ${clst_hostarch} in
# CD image, and then pass these components to the
# `sgibootcd` tool which outputs a final CD image
scratch="${1}"
-   mkdir -p mkdir ${scratch}/{kernels/misc,arcload}
+   mkdir -p ${scratch}/{kernels/misc,arcload}
echo "" > ${scratch}/arc.cf
 
# Move kernel binaries to ${scratch}/kernels, and



[gentoo-commits] repo/gentoo:master commit in: games-simulation/openrct2/

2020-04-07 Thread Conrad Kostecki
commit: a716da7d8138514e6fad3513238d749c1bfd3d42
Author: Conrad Kostecki  gentoo  org>
AuthorDate: Tue Apr  7 16:06:23 2020 +
Commit: Conrad Kostecki  gentoo  org>
CommitDate: Tue Apr  7 16:08:36 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=a716da7d

games-simulation/openrct2: update resources

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Conrad Kostecki  gentoo.org>

 games-simulation/openrct2/Manifest | 2 ++
 games-simulation/openrct2/openrct2-.ebuild | 6 +++---
 2 files changed, 5 insertions(+), 3 deletions(-)

diff --git a/games-simulation/openrct2/Manifest 
b/games-simulation/openrct2/Manifest
index 95e80e71498..e6fbee6b94e 100644
--- a/games-simulation/openrct2/Manifest
+++ b/games-simulation/openrct2/Manifest
@@ -1,4 +1,6 @@
 DIST openrct2-0.2.4.tar.gz 6805976 BLAKE2B 
7860746d1705804682756097ff37d4584d0ebb20c450c08b88134795e9f3c375dfb888a67302f530cd55700eaa5cd13149c365c30a5d267d382b39225f06d210
 SHA512 
956044b5fa5e55256a33f352d2d1e8a4eb6738b98dc9894807b3628b5c5c08f3229c952fbf8b33ad867771f88c6d7e17ad1a8a4e050f8f269a6152d013afce03
 DIST openrct2-objects-1.0.12.zip 2173875 BLAKE2B 
d344dde3dc376004b9e303a489c058a574c2f8babcce8c9998ef12f2b91e3fe7d3e22e1afc81aadd39637f3f91a5d36c4267aed06980686fd909cc515f4c8fde
 SHA512 
d17d2197b66d22e33a246651a0c544a49a6d6a809612d26a851dc4b40bb9e1bf5079bbe5b1a3b7d41f541fc41ce41717d772a5579aa2cdc9ec1dfea72b5a3144
+DIST openrct2-objects-1.0.13.zip 2214431 BLAKE2B 
6301c787364cb16a4f599c2b94d475237abd098715a98a0bfe87fc067d490f8939c5f25235350d9fed02c37d4f92a29c2bb021a9acf1615f161e5b5d95b8fd63
 SHA512 
690255506e3286bff00076f3dcb3ce50e98606dfc1e522aa679d5e6c7e01c5f56a6624a65bb8aab5915d7d71ae21de310642c16cd5154db6b096bedd77d5797e
 DIST openrct2-replays-0.0.4.zip 1098833 BLAKE2B 
efe4f72b16285d8e6508313f16b892b02f1b124cf9b4d146731280f5090d071d3351834e6d4ab51122804fbbcb49044be4e681182141aac93795c3b1953b6590
 SHA512 
5c2469bfdaa94a6007f6788878f4e80d87fbbfd48b522e1bd2a22c2aa0c98583159b9559fd45f7f9450d544a99a59b6c17399d9ac91a171a86135f0e1a5b3e71
+DIST openrct2-replays-0.0.8.zip 1038537 BLAKE2B 
7b6da300cb588676aceb75c440b0e7d4bcdf0e44d889a21a381d45c8b3237f362bd33c53998795845904a2b6ea8bde38efa5bcea5f4d73d1b2ed876382abaa3e
 SHA512 
60b95d89691c83054627829ddc4aa8c7c85dd7f4e2b268834e05aba724bf42e3968d14b158d6277fcf74fa81c1ec4f063c20cf6c940b8707538747d86eeacd94
 DIST openrct2-title-sequences-0.1.2c.zip 2980030 BLAKE2B 
f91168bea0a4f88a801c95ea45759e0d1c887a89c18dbbded5887d2914db7119dd65c231aa422e4f8a964a81d832eae05bffaa8b7908fac39a63792d082b53a0
 SHA512 
0e544d236d5f6ac7f68d75ba1f56f043c76c77676cbb92e6fdbf68a6ae2dc6c41dbdad6083ceec36b2f774bcdd99f64f28de73b208d6a39a8218a9e95502d46e

diff --git a/games-simulation/openrct2/openrct2-.ebuild 
b/games-simulation/openrct2/openrct2-.ebuild
index 80ce2ffbfd6..eba6373879b 100644
--- a/games-simulation/openrct2/openrct2-.ebuild
+++ b/games-simulation/openrct2/openrct2-.ebuild
@@ -1,4 +1,4 @@
-# Copyright 1999-2019 Gentoo Authors
+# Copyright 1999-2020 Gentoo Authors
 # Distributed under the terms of the GNU General Public License v2
 
 EAPI=7
@@ -12,8 +12,8 @@ MY_PN="OpenRCT2"
 MY_PN_OBJ="objects"
 MY_PN_RPL="replays"
 MY_PN_TS="title-sequences"
-MY_PV_OBJ="1.0.12"
-MY_PV_RPL="0.0.4"
+MY_PV_OBJ="1.0.13"
+MY_PV_RPL="0.0.8"
 MY_PV_TS="0.1.2c"
 
 DESCRIPTION="An open source re-implementation of Chris Sawyer's RollerCoaster 
Tycoon 2"



[gentoo-commits] repo/gentoo:master commit in: net-im/zoom/

2020-04-07 Thread Ulrich Müller
commit: b4db2e99a55efbabd24b2989c7edd9bc6a778fcb
Author: Ulrich Müller  gentoo  org>
AuthorDate: Tue Apr  7 15:33:26 2020 +
Commit: Ulrich Müller  gentoo  org>
CommitDate: Tue Apr  7 16:09:21 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=b4db2e99

net-im/zoom: Fix dependencies on x86.

Closes: https://bugs.gentoo.org/716568
Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Ulrich Müller  gentoo.org>

 net-im/zoom/zoom-3.5.374815.0324-r4.ebuild | 13 +
 1 file changed, 9 insertions(+), 4 deletions(-)

diff --git a/net-im/zoom/zoom-3.5.374815.0324-r4.ebuild 
b/net-im/zoom/zoom-3.5.374815.0324-r4.ebuild
index 1586c1e66eb..15de2f97fc1 100644
--- a/net-im/zoom/zoom-3.5.374815.0324-r4.ebuild
+++ b/net-im/zoom/zoom-3.5.374815.0324-r4.ebuild
@@ -25,12 +25,8 @@ RDEPEND="dev-libs/glib:2
dev-qt/qtgraphicaleffects:5
dev-qt/qtgui:5
dev-qt/qtnetwork:5
-   dev-qt/qtpositioning:5
-   dev-qt/qtprintsupport:5
dev-qt/qtquickcontrols:5[widgets]
dev-qt/qtscript:5
-   dev-qt/qtwebchannel:5
-   dev-qt/qtwebengine:5
dev-qt/qtwidgets:5
media-libs/libglvnd
media-libs/libjpeg-turbo
@@ -44,6 +40,15 @@ RDEPEND="dev-libs/glib:2
x11-libs/libXtst
x11-libs/xcb-util-image
x11-libs/xcb-util-keysyms
+   amd64? (
+   dev-qt/qtpositioning:5
+   dev-qt/qtprintsupport:5
+   dev-qt/qtwebchannel:5
+   dev-qt/qtwebengine:5
+   )
+   x86? (
+   dev-qt/qtwebkit:5
+   )
pulseaudio? ( media-sound/pulseaudio )
!pulseaudio? ( media-libs/alsa-lib )"
 



[gentoo-commits] repo/gentoo:master commit in: games-simulation/openrct2/

2020-04-07 Thread Conrad Kostecki
commit: 56bd7e539cad8c868ad32280f802ca27f3b7a682
Author: Conrad Kostecki  gentoo  org>
AuthorDate: Tue Apr  7 16:08:17 2020 +
Commit: Conrad Kostecki  gentoo  org>
CommitDate: Tue Apr  7 16:08:37 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=56bd7e53

games-simulation/openrct2: bump to version 0.2.5

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Conrad Kostecki  gentoo.org>

 games-simulation/openrct2/Manifest  |   1 +
 games-simulation/openrct2/openrct2-0.2.5.ebuild | 162 
 2 files changed, 163 insertions(+)

diff --git a/games-simulation/openrct2/Manifest 
b/games-simulation/openrct2/Manifest
index e6fbee6b94e..98c1c90754f 100644
--- a/games-simulation/openrct2/Manifest
+++ b/games-simulation/openrct2/Manifest
@@ -1,4 +1,5 @@
 DIST openrct2-0.2.4.tar.gz 6805976 BLAKE2B 
7860746d1705804682756097ff37d4584d0ebb20c450c08b88134795e9f3c375dfb888a67302f530cd55700eaa5cd13149c365c30a5d267d382b39225f06d210
 SHA512 
956044b5fa5e55256a33f352d2d1e8a4eb6738b98dc9894807b3628b5c5c08f3229c952fbf8b33ad867771f88c6d7e17ad1a8a4e050f8f269a6152d013afce03
+DIST openrct2-0.2.5.tar.gz 11076466 BLAKE2B 
7e3aff0e2a322b1a0319df6ebdc335052d5aeb0c35dc97123fcf316272e95171ced5f9f41695d986b69b93cdacfa755fef924e2ff87a3f2441e03fd33175a2cc
 SHA512 
8ab091788a52408ef37d603581841a12ffbe5a5eced43504d8e19e89d26b1320010dc0b4a4b67080260e66e24edeb2c780d7bad9b88b58e6a7216f4e393fc516
 DIST openrct2-objects-1.0.12.zip 2173875 BLAKE2B 
d344dde3dc376004b9e303a489c058a574c2f8babcce8c9998ef12f2b91e3fe7d3e22e1afc81aadd39637f3f91a5d36c4267aed06980686fd909cc515f4c8fde
 SHA512 
d17d2197b66d22e33a246651a0c544a49a6d6a809612d26a851dc4b40bb9e1bf5079bbe5b1a3b7d41f541fc41ce41717d772a5579aa2cdc9ec1dfea72b5a3144
 DIST openrct2-objects-1.0.13.zip 2214431 BLAKE2B 
6301c787364cb16a4f599c2b94d475237abd098715a98a0bfe87fc067d490f8939c5f25235350d9fed02c37d4f92a29c2bb021a9acf1615f161e5b5d95b8fd63
 SHA512 
690255506e3286bff00076f3dcb3ce50e98606dfc1e522aa679d5e6c7e01c5f56a6624a65bb8aab5915d7d71ae21de310642c16cd5154db6b096bedd77d5797e
 DIST openrct2-replays-0.0.4.zip 1098833 BLAKE2B 
efe4f72b16285d8e6508313f16b892b02f1b124cf9b4d146731280f5090d071d3351834e6d4ab51122804fbbcb49044be4e681182141aac93795c3b1953b6590
 SHA512 
5c2469bfdaa94a6007f6788878f4e80d87fbbfd48b522e1bd2a22c2aa0c98583159b9559fd45f7f9450d544a99a59b6c17399d9ac91a171a86135f0e1a5b3e71

diff --git a/games-simulation/openrct2/openrct2-0.2.5.ebuild 
b/games-simulation/openrct2/openrct2-0.2.5.ebuild
new file mode 100644
index 000..55734f4bd98
--- /dev/null
+++ b/games-simulation/openrct2/openrct2-0.2.5.ebuild
@@ -0,0 +1,162 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit cmake-utils readme.gentoo-r1 xdg-utils
+
+MY_PN="OpenRCT2"
+MY_PN_OBJ="objects"
+MY_PN_RPL="replays"
+MY_PN_TS="title-sequences"
+MY_PV_OBJ="1.0.13"
+MY_PV_RPL="0.0.8"
+MY_PV_TS="0.1.2c"
+
+DESCRIPTION="An open source re-implementation of Chris Sawyer's RollerCoaster 
Tycoon 2"
+HOMEPAGE="https://openrct2.org/;
+SRC_URI="
+   https://github.com/${MY_PN}/${MY_PN}/archive/v${PV}.tar.gz -> 
${P}.tar.gz
+   
https://github.com/${MY_PN}/${MY_PN_OBJ}/releases/download/v${MY_PV_OBJ}/${MY_PN_OBJ}.zip
 -> ${PN}-${MY_PN_OBJ}-${MY_PV_OBJ}.zip
+   
https://github.com/${MY_PN}/${MY_PN_TS}/releases/download/v${MY_PV_TS}/${MY_PN_TS}.zip
 -> ${PN}-${MY_PN_TS}-${MY_PV_TS}.zip
+   test? ( 
https://github.com/${MY_PN}/${MY_PN_RPL}/releases/download/v${MY_PV_RPL}/${MY_PN_RPL}.zip
 -> ${PN}-${MY_PN_RPL}-${MY_PV_RPL}.zip )
+"
+
+LICENSE="GPL-3"
+SLOT="0"
+KEYWORDS="~amd64 ~x86"
+IUSE="dedicated libressl +lightfx +opengl test +truetype twitch"
+
+COMMON_DEPEND="
+   dev-libs/icu:=
+   dev-libs/jansson
+   dev-libs/libzip:=
+   media-libs/libpng:0=
+   sys-libs/zlib
+   !dedicated? (
+   media-libs/libsdl2
+   media-libs/speexdsp
+   opengl? ( virtual/opengl )
+   twitch? (
+   net-misc/curl[ssl]
+   )
+   )
+   libressl? ( dev-libs/libressl:0= )
+   !libressl? ( dev-libs/openssl:0= )
+   truetype? (
+   media-libs/fontconfig:1.0
+   media-libs/freetype:2
+   )
+"
+
+RDEPEND="
+   ${COMMON_DEPEND}
+   dedicated? (
+   acct-group/openrct2
+   acct-user/openrct2
+   )
+"
+
+DEPEND="
+   ${COMMON_DEPEND}
+   test? ( dev-cpp/gtest )
+"
+
+BDEPEND="
+   app-arch/unzip
+   virtual/pkgconfig
+"
+
+RESTRICT="!test? ( test )"
+
+S="${WORKDIR}/${MY_PN}-${PV}"
+
+PATCHES=(
+   "${FILESDIR}/${PN}-0.2.4-include-additional-paths.patch"
+)
+
+src_unpack() {
+   unpack "${P}".tar.gz
+
+   mkdir -p "${S}"/data/title || die
+   cd "${S}"/data/title || die
+   unpack "${PN}-${MY_PN_TS}-${MY_PV_TS}".zip
+
+   mkdir -p "${S}"/data/object || die
+   cd "${S}"/data/object 

[gentoo-commits] repo/gentoo:master commit in: net-im/zoom/

2020-04-07 Thread Ulrich Müller
commit: ea657c535c7ee57bbbef3236781658c5910e7acd
Author: Ulrich Müller  gentoo  org>
AuthorDate: Tue Apr  7 15:35:11 2020 +
Commit: Ulrich Müller  gentoo  org>
CommitDate: Tue Apr  7 16:09:22 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=ea657c53

net-im/zoom: Version bump to 3.5.382995.0407.

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Ulrich Müller  gentoo.org>

 net-im/zoom/Manifest|  2 +
 net-im/zoom/zoom-3.5.382995.0407.ebuild | 98 +
 2 files changed, 100 insertions(+)

diff --git a/net-im/zoom/Manifest b/net-im/zoom/Manifest
index cdc31852c2c..3f6534909a3 100644
--- a/net-im/zoom/Manifest
+++ b/net-im/zoom/Manifest
@@ -1,2 +1,4 @@
 DIST zoom-3.5.374815.0324_i686.tar.xz 48481420 BLAKE2B 
5c40be4c5cf1e72766f35ea971384c514a49f8ed882af6791b7681c84082830ee120147fcd138b382509b4ebf5dc84a479f2ad40e7eed0dd332a02d4bc141d8c
 SHA512 
354e7e8af733dad1483e138621574f675822fe9f5739092a11495f6f584917413012866d171e076b7156c6097e71c85f8e53dba1fd9db2de59af55256ab8479e
 DIST zoom-3.5.374815.0324_x86_64.tar.xz 72609300 BLAKE2B 
2f51eecd88cc636f03778c68101b2c5919982025232da5cd6a378a2e681ad76d39d9db201ff14d5601498495909dfb934ebf21752cd7658ada6edc28379bed90
 SHA512 
632002b6942f15e1f22ba147de9a9463253c2b374e4382b4c2ce21e5685ad4fd688929141095d09e2fa0ed2adb5b0dc6ba9aba2e4fa54ae69fea24b95bf474c4
+DIST zoom-3.5.382995.0407_i686.tar.xz 48494772 BLAKE2B 
13d678c36bac7e5705cc0608d0ca49d943e56b492cce802f41ffe6bbb307336fef4e710346f33e596faa84a449b1f69ef944e462b694aff016051a834e1d2a89
 SHA512 
339abb803cd08e6835404ff2f1140b9ee73294a8820828d833b64e3bfe619fd24eb18c475b78a0f795a63dadc8ffd6593563710d6e8ba606fcbf3ffd7a007c33
+DIST zoom-3.5.382995.0407_x86_64.tar.xz 72616840 BLAKE2B 
3a20f9346305ec84c6b14233724dce6ab285810e7c59ed482139e902f088e2cf7f1f48d769fe0f0990128f92aa4221f7fe5f69e9d5859fc5bf6d57378ec25507
 SHA512 
d0612f83d23e93e84db5dd18c55ebc6b3cba17b9479ff812276e0d1fb21fb9fbe2fe5f38329f5e30cd7acf6c7f88fdf09d6dd31d223e3edec0bc1142b358bb8b

diff --git a/net-im/zoom/zoom-3.5.382995.0407.ebuild 
b/net-im/zoom/zoom-3.5.382995.0407.ebuild
new file mode 100644
index 000..15de2f97fc1
--- /dev/null
+++ b/net-im/zoom/zoom-3.5.382995.0407.ebuild
@@ -0,0 +1,98 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+
+inherit desktop eutils xdg-utils
+
+DESCRIPTION="Video conferencing and web conferencing service"
+HOMEPAGE="https://zoom.us/;
+SRC_URI="amd64? ( https://zoom.us/client/${PV}/${PN}_x86_64.tar.xz -> 
${P}_x86_64.tar.xz )
+   x86? ( https://zoom.us/client/${PV}/${PN}_i686.tar.xz -> 
${P}_i686.tar.xz )"
+S="${WORKDIR}/${PN}"
+
+LICENSE="all-rights-reserved Apache-2.0" # Apache-2.0 for icon
+SLOT="0"
+KEYWORDS="-* ~amd64 ~x86"
+IUSE="pulseaudio"
+RESTRICT="mirror bindist strip"
+
+RDEPEND="dev-libs/glib:2
+   dev-libs/icu
+   dev-qt/qtcore:5
+   dev-qt/qtdbus:5
+   dev-qt/qtdeclarative:5
+   dev-qt/qtgraphicaleffects:5
+   dev-qt/qtgui:5
+   dev-qt/qtnetwork:5
+   dev-qt/qtquickcontrols:5[widgets]
+   dev-qt/qtscript:5
+   dev-qt/qtwidgets:5
+   media-libs/libglvnd
+   media-libs/libjpeg-turbo
+   media-sound/mpg123
+   sys-apps/dbus
+   sys-apps/util-linux
+   x11-libs/libX11
+   x11-libs/libxcb
+   x11-libs/libXext
+   x11-libs/libXfixes
+   x11-libs/libXtst
+   x11-libs/xcb-util-image
+   x11-libs/xcb-util-keysyms
+   amd64? (
+   dev-qt/qtpositioning:5
+   dev-qt/qtprintsupport:5
+   dev-qt/qtwebchannel:5
+   dev-qt/qtwebengine:5
+   )
+   x86? (
+   dev-qt/qtwebkit:5
+   )
+   pulseaudio? ( media-sound/pulseaudio )
+   !pulseaudio? ( media-libs/alsa-lib )"
+
+BDEPEND="!pulseaudio? ( dev-util/bbe )"
+
+QA_PREBUILT="opt/zoom/*"
+
+src_prepare() {
+   default
+   if ! use pulseaudio; then
+   # For some strange reason, zoom cannot use any ALSA sound 
devices if
+   # it finds libpulse. This causes breakage if 
media-sound/apulse[sdk]
+   # is installed. So, force zoom to ignore libpulse.
+   bbe -e 's/libpulse.so/IgNoRePuLsE/' zoom >zoom.tmp || die
+   mv zoom.tmp zoom || die
+   fi
+}
+
+src_install() {
+   insinto /opt/zoom
+   exeinto /opt/zoom
+   doins -r json sip timezones translations
+   doins *.pcm *.pem *.sh Embedded.properties version.txt
+   use amd64 && doins icudtl.dat
+   doexe zoom{,.sh,linux} zopen ZoomLauncher
+   dosym {"../../usr/$(get_libdir)",/opt/zoom}/libmpg123.so
+   dosym {"../../usr/$(get_libdir)",/opt/zoom}/libturbojpeg.so #715106
+
+   make_wrapper zoom ./zoom /opt/zoom
+   make_desktop_entry "zoom %U" Zoom zoom-videocam "" \
+   "MimeType=x-scheme-handler/zoommtg;application/x-zoom;"
+   # The tarball doesn't contain an 

[gentoo-commits] repo/gentoo:master commit in: net-libs/librsync/files/, net-libs/librsync/

2020-04-07 Thread Bernard Cafarelli
commit: 445e9abb3b4e92f405df48ceda7608b9c9028461
Author: Bernard Cafarelli  gentoo  org>
AuthorDate: Tue Apr  7 16:01:53 2020 +
Commit: Bernard Cafarelli  gentoo  org>
CommitDate: Tue Apr  7 16:02:30 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=445e9abb

Revert "net-libs/librsync: drop old stable"

This reverts commit e28b02899c01823dbec2d41261a1b532f5077f65.
net-misc/dropbox has optional dependency on  gentoo.org>

 net-libs/librsync/Manifest |  1 +
 .../files/librsync-0.9.7-fix-testsuite.patch   | 15 +
 .../files/librsync-0.9.7-format-security.patch | 20 
 .../librsync/files/librsync-0.9.7-getopt.patch | 17 ++
 .../librsync/files/librsync-0.9.7-huge-files.patch | 31 +++
 .../librsync-0.9.7-implicit-declaration.patch  | 19 
 net-libs/librsync/librsync-0.9.7-r3.ebuild | 36 ++
 7 files changed, 139 insertions(+)

diff --git a/net-libs/librsync/Manifest b/net-libs/librsync/Manifest
index 04758c6b00f..1ba8bce2c89 100644
--- a/net-libs/librsync/Manifest
+++ b/net-libs/librsync/Manifest
@@ -1,3 +1,4 @@
+DIST librsync-0.9.7.tar.gz 453802 BLAKE2B 
0f8a7a758d847498876401aa04473946970be0257dc0cc4abce85adc7adb5d480d7a41e03d43f667e44ec646ce74a75dfa6b0c63c7f239338244b67eb432e31f
 SHA512 
339362fd01c94411849d3e4a6e95db1bef6cffa0475b1af49d73f11be0421a12d4c73ecbf1a272af01b2a21cec81b4a801c1f7d735e107d0242707fb4c45f9ef
 DIST librsync-2.0.1.tar.gz 169765 BLAKE2B 
3b3a109307dc03e567338709f1c3958a2ae7887165208848359677305f6a983edc1bc71c721dd3f414f77e0507426ae5bb59b9fde51595a92379227ac316127a
 SHA512 
70c1ed0f3a8ad8c1201ce67b5411c4aabb4c78ba9d60e4ee658d9a8818c6511322abd53b583869b8927a29b0f105e1a5c9b05efa748eb435e8fc3b7be3344e04
 DIST librsync-2.0.2.tar.gz 174480 BLAKE2B 
e77d554ad08a852459fe2798249f47ca7f26849b4b8622c5b64f7f9b6d23f1fedc443f747c7988679a3548ea1f6fd2902c424717faaf73a5cfd7e19012a2d72d
 SHA512 
5d2bc1d62b37e9ed7416203615d0a0e3c05c4c884b5da63eda10dd5c985845b500331bce226e4d45676729382c85b41528282e25d491afda31ba434ac0fefad7
 DIST librsync-2.1.0.tar.gz 175630 BLAKE2B 
effd2a8c79fae202921220db7581be1d9f7d278e6ee5155a23e586d9d4a7a27bbc4a50049ddca3b187a8e08451c6dcde7340d22be9fde0c2c12462392043fd8e
 SHA512 
9b91f4b696c1d1cdacb5c0679c7df7a92641e0a6a599c2e5de2bc0af3052b2045bb16c40b072c40859074d792c78c57afb0817917fa9843b179befa4506ebf04

diff --git a/net-libs/librsync/files/librsync-0.9.7-fix-testsuite.patch 
b/net-libs/librsync/files/librsync-0.9.7-fix-testsuite.patch
new file mode 100644
index 000..e87c3d8f67b
--- /dev/null
+++ b/net-libs/librsync/files/librsync-0.9.7-fix-testsuite.patch
@@ -0,0 +1,15 @@
+Description: Fix running tests with the parallel harness
+Author: Andrey Rahmatullin 
+Last-Update: 2013-06-26
+
+--- a/testsuite/Makefile.am
 b/testsuite/Makefile.am
+@@ -29,7 +29,7 @@ isprefix_driver_LDADD = ../isprefix.o # XXX: should link 
replaced functions
+ # failed.  Generally these tests should be ordered so that more basic
+ # tests are run first.
+ 
+-TESTS_ENVIRONMENT = $(SH) $(srcdir)/driver.sh
++TEST_LOG_COMPILER = $(SH) $(srcdir)/driver.sh
+ 
+ TESTS = \
+   signature.test mutate.test sources.test isprefix.test   \

diff --git a/net-libs/librsync/files/librsync-0.9.7-format-security.patch 
b/net-libs/librsync/files/librsync-0.9.7-format-security.patch
new file mode 100644
index 000..e35980a4d7a
--- /dev/null
+++ b/net-libs/librsync/files/librsync-0.9.7-format-security.patch
@@ -0,0 +1,20 @@
+Description: Always use a format string in printf
+ Fix the warning: buf.c:216:9: error: format not a string literal and no
+ format arguments [-Werror=format-security]
+Author: Andrey Rahmatullin 
+Forwarded: no
+Last-Update: 2012-02-05
+
+diff --git a/buf.c b/buf.c
+index 7f4e7a0..3a83f2b 100644
+--- a/buf.c
 b/buf.c
+@@ -213,7 +213,7 @@ rs_result rs_file_copy_cb(void *arg, rs_long_t pos, size_t 
*len, void **buf)
+ 
+ got = fread(*buf, 1, *len, f);
+ if (got == -1) {
+-rs_error(strerror(errno));
++rs_error("%s", strerror(errno));
+ return RS_IO_ERROR;
+ } else if (got == 0) {
+ rs_error("unexpected eof on fd%d", fileno(f));

diff --git a/net-libs/librsync/files/librsync-0.9.7-getopt.patch 
b/net-libs/librsync/files/librsync-0.9.7-getopt.patch
new file mode 100644
index 000..0859089b970
--- /dev/null
+++ b/net-libs/librsync/files/librsync-0.9.7-getopt.patch
@@ -0,0 +1,17 @@
+Patch by Daniel Baumann  for librsync >= 0.9.7, which makes
+rdiff aware of -i and -z getopt options mentioned in --help output. For further
+information, please have a look to Debian bug ID #435894.
+
+--- librsync-0.9.7/rdiff.c 2004-09-17 23:35:50.0 
+0200
 librsync-0.9.7/rdiff.c.getopt  2008-12-20 13:45:58.0 
+0100
+@@ -97,8 +97,8 @@
+ { "sum-size",'S', POPT_ARG_INT,  _len },
+ { "statistics",  's', POPT_ARG_NONE, _stats },
+ { 

[gentoo-commits] repo/gentoo:master commit in: x11-wm/windowmaker/

2020-04-07 Thread Bernard Cafarelli
commit: 851508a9add21d0ffab93fdccda1186ada4a4c43
Author: Bernard Cafarelli  gentoo  org>
AuthorDate: Tue Apr  7 15:18:53 2020 +
Commit: Bernard Cafarelli  gentoo  org>
CommitDate: Tue Apr  7 15:18:53 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=851508a9

x11-wm/windowmaker: drop old stable

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Bernard Cafarelli  gentoo.org>

 x11-wm/windowmaker/Manifest  |   1 -
 x11-wm/windowmaker/windowmaker-0.95.7.ebuild | 104 ---
 2 files changed, 105 deletions(-)

diff --git a/x11-wm/windowmaker/Manifest b/x11-wm/windowmaker/Manifest
index 0ed27da2d38..d1a8f49c43d 100644
--- a/x11-wm/windowmaker/Manifest
+++ b/x11-wm/windowmaker/Manifest
@@ -1,3 +1,2 @@
-DIST WindowMaker-0.95.7.tar.gz 3238325 BLAKE2B 
68a26e8b1281a4ff387fa87517efb46995e5339e2e6e7f71303d3e3e0d75316740d2458067dc4159f23bf1e1b4e1e0bfc22b1428ee4933e4d474a79a147baaf7
 SHA512 
9c1190503efdc58c11a90d5ba80796979cdc9f2beb69a6d233ffc8d531a54c877c5270841bf6318738069098cd488e5ab77ac19f661ac888e892bf05ac22d93f
 DIST WindowMaker-0.95.8.tar.gz 3253515 BLAKE2B 
225dae9eb10f913931e129fdf78860123a14406ad8e61ba42fe4eadcf5d3f03c88040a2b982e74abaf79088f4a063291ccfb7b7d42f1bf211adb7b02c765a664
 SHA512 
6ab16ed4304aba20f0f3a4083adf63a47fa674ade7bc39aaa8aa6466c7842e3f10ab73af96e2afce0842b11c57a35eb69f43183a4044d8cd95d4e2a4d2c079a2
 DIST WindowMaker-extra-0.1.tar.gz 238018 BLAKE2B 
865b12975d0cdefc1f05a76344b449fdcf8a2841d6a7adf1ab6435857d89cbc4fda22bb62432a1bbba921267380d00a0cded718bfbd344bbb5e6207e59b76096
 SHA512 
0fe9b3ffc093942db167d8a01e15c0f6741f3a40959d1434ea4f23e7b9d4a9c13935a61eabef9691e5fdfd4e407564caafce15c2d65d66499960a6764a874ab8

diff --git a/x11-wm/windowmaker/windowmaker-0.95.7.ebuild 
b/x11-wm/windowmaker/windowmaker-0.95.7.ebuild
deleted file mode 100644
index 529214e50d4..000
--- a/x11-wm/windowmaker/windowmaker-0.95.7.ebuild
+++ /dev/null
@@ -1,104 +0,0 @@
-# Copyright 1999-2020 Gentoo Authors
-# Distributed under the terms of the GNU General Public License v2
-
-EAPI=5
-inherit eutils
-
-DESCRIPTION="The fast and light GNUstep window manager"
-HOMEPAGE="http://www.windowmaker.org/;
-SRC_URI="http://windowmaker.org/pub/source/release/${P/windowm/WindowM}.tar.gz
-   
http://www.windowmaker.org/pub/source/release/WindowMaker-extra-0.1.tar.gz;
-
-SLOT="0"
-LICENSE="GPL-2"
-IUSE="gif imagemagick jpeg modelock nls png tiff webp xinerama +xpm xrandr"
-KEYWORDS="~alpha amd64 ~arm hppa ~mips ppc ~ppc64 sparc x86 ~amd64-linux 
~x86-linux ~ppc-macos ~x86-macos ~sparc-solaris ~x64-solaris ~x86-solaris"
-
-DEPEND="media-libs/fontconfig
-   >=x11-libs/libXft-2.1.0
-   x11-libs/libXmu
-   x11-libs/libXpm
-   x11-libs/libXt
-   x11-libs/libXv
-   gif? ( >=media-libs/giflib-4.1.0-r3 )
-   imagemagick? ( media-gfx/imagemagick )
-   jpeg? ( virtual/jpeg:0= )
-   png? ( media-libs/libpng:0= )
-   tiff? ( media-libs/tiff:0 )
-   webp? ( media-libs/libwebp )
-   xinerama? ( x11-libs/libXinerama )
-   xrandr? ( x11-libs/libXrandr )"
-RDEPEND="${DEPEND}
-   nls? ( >=sys-devel/gettext-0.10.39 )"
-
-S=${WORKDIR}/${P/windowm/WindowM}
-
-src_prepare() {
-   # Fix some paths
-   for file in WindowMaker/*menu* util/wmgenmenu.c; do
-   if [[ -r $file ]] ; then
-   sed -i -e 
"s:/usr/local/GNUstep/Applications/WPrefs.app:${EPREFIX}/usr/bin/:g;" "$file" 
|| die
-   sed -i -e 
"s:/usr/local/share/WindowMaker:${EPREFIX}/usr/share/WindowMaker:g;" "$file" || 
die
-   sed -i -e 
"s:/opt/share/WindowMaker:${EPREFIX}/usr/share/WindowMaker:g;" "$file" || die
-   fi;
-   done;
-}
-
-src_configure() {
-   local myconf
-
-   # image format types
-   myconf="$(use_enable imagemagick magick) $(use_enable jpeg) 
$(use_enable gif) $(use_enable png) $(use_enable tiff) $(use_enable webp) 
$(use_enable xpm)"
-
-   # non required X capabilities
-   myconf="${myconf} $(use_enable modelock) $(use_enable xrandr randr) 
$(use_enable xinerama)"
-
-   if use nls; then
-   [[ -z $LINGUAS ]] && export LINGUAS="$(ls po/*.po | sed 
's:po/\(.*\)\.po$:\1:' | xargs)"
-   else
-   myconf="${myconf} --disable-locale"
-   fi
-
-   # default settings with $myconf appended
-   econf \
-   --sysconfdir="${EPREFIX}"/etc/X11 \
-   --with-x \
-   --enable-usermenu \
-   --with-pixmapdir="${EPREFIX}"/usr/share/pixmaps \
-   --localedir="${EPREFIX}"/usr/share/locale \
-   ${myconf}
-
-   cd ../WindowMaker-extra-0.1
-   econf
-}
-
-src_compile() {
-   emake
-
-   # WindowMaker Extra Package (themes and icons)
-   cd ../WindowMaker-extra-0.1
-   emake
-}
-
-src_install() {
-   emake DESTDIR="${D}" install
-
-   dodoc AUTHORS BUGFORM BUGS ChangeLog INSTALL* FAQ* 

[gentoo-commits] repo/gentoo:master commit in: x11-wm/windowmaker/

2020-04-07 Thread Bernard Cafarelli
commit: 6969ea122a627841089788b1c61dfcb1b0277954
Author: Bernard Cafarelli  gentoo  org>
AuthorDate: Tue Apr  7 15:46:11 2020 +
Commit: Bernard Cafarelli  gentoo  org>
CommitDate: Tue Apr  7 15:46:11 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=6969ea12

x11-wm/windowmaker: 0.95.9 bump

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Bernard Cafarelli  gentoo.org>

 x11-wm/windowmaker/Manifest  |   1 +
 x11-wm/windowmaker/windowmaker-0.95.9.ebuild | 108 +++
 2 files changed, 109 insertions(+)

diff --git a/x11-wm/windowmaker/Manifest b/x11-wm/windowmaker/Manifest
index d1a8f49c43d..203c74888ef 100644
--- a/x11-wm/windowmaker/Manifest
+++ b/x11-wm/windowmaker/Manifest
@@ -1,2 +1,3 @@
 DIST WindowMaker-0.95.8.tar.gz 3253515 BLAKE2B 
225dae9eb10f913931e129fdf78860123a14406ad8e61ba42fe4eadcf5d3f03c88040a2b982e74abaf79088f4a063291ccfb7b7d42f1bf211adb7b02c765a664
 SHA512 
6ab16ed4304aba20f0f3a4083adf63a47fa674ade7bc39aaa8aa6466c7842e3f10ab73af96e2afce0842b11c57a35eb69f43183a4044d8cd95d4e2a4d2c079a2
+DIST WindowMaker-0.95.9.tar.gz 3397167 BLAKE2B 
ec751fe0139b359933f4388f8dac3f2bf18db1f28fb4cb290d86db1ded9ffdab0cf51b451e28475bc51ee2735cb71c7fd2b01fa7472f5f0f4f1a1e00e1509339
 SHA512 
ca3ddc863f5b5b782e90f38c0019fe14d1109d6b11d0a3d5d6c728ddc1817747eea92e22e36933d445e72c70661e039ee56efa70f2654657c8980269fd5b4584
 DIST WindowMaker-extra-0.1.tar.gz 238018 BLAKE2B 
865b12975d0cdefc1f05a76344b449fdcf8a2841d6a7adf1ab6435857d89cbc4fda22bb62432a1bbba921267380d00a0cded718bfbd344bbb5e6207e59b76096
 SHA512 
0fe9b3ffc093942db167d8a01e15c0f6741f3a40959d1434ea4f23e7b9d4a9c13935a61eabef9691e5fdfd4e407564caafce15c2d65d66499960a6764a874ab8

diff --git a/x11-wm/windowmaker/windowmaker-0.95.9.ebuild 
b/x11-wm/windowmaker/windowmaker-0.95.9.ebuild
new file mode 100644
index 000..a11fcfdcd36
--- /dev/null
+++ b/x11-wm/windowmaker/windowmaker-0.95.9.ebuild
@@ -0,0 +1,108 @@
+# Copyright 1999-2020 Gentoo Authors
+# Distributed under the terms of the GNU General Public License v2
+
+EAPI=7
+inherit autotools eutils
+
+DESCRIPTION="The fast and light GNUstep window manager"
+HOMEPAGE="http://www.windowmaker.org/;
+SRC_URI="http://windowmaker.org/pub/source/release/${P/windowm/WindowM}.tar.gz
+   
http://www.windowmaker.org/pub/source/release/WindowMaker-extra-0.1.tar.gz;
+
+SLOT="0"
+LICENSE="GPL-2"
+IUSE="gif imagemagick jpeg modelock nls png tiff webp xinerama +xpm xrandr"
+KEYWORDS="~alpha ~amd64 ~arm ~hppa ~mips ~ppc ~ppc64 ~sparc ~x86 ~amd64-linux 
~x86-linux ~ppc-macos ~x86-macos ~sparc-solaris ~x64-solaris ~x86-solaris"
+
+DEPEND="media-libs/fontconfig
+   >=x11-libs/libXft-2.1.0
+   x11-libs/libXmu
+   x11-libs/libXpm
+   x11-libs/libXt
+   x11-libs/libXv
+   gif? ( >=media-libs/giflib-4.1.0-r3 )
+   imagemagick? ( >=media-gfx/imagemagick-7:0= )
+   jpeg? ( virtual/jpeg:0= )
+   png? ( media-libs/libpng:0= )
+   tiff? ( media-libs/tiff:0 )
+   webp? ( media-libs/libwebp )
+   xinerama? ( x11-libs/libXinerama )
+   xrandr? ( x11-libs/libXrandr )"
+RDEPEND="${DEPEND}
+   nls? ( >=sys-devel/gettext-0.10.39 )"
+
+S=${WORKDIR}/${P/windowm/WindowM}
+
+DOCS=( AUTHORS BUGFORM BUGS ChangeLog INSTALL INSTALL-WMAKER FAQ
+   NEWS README README.definable-cursor README.i18n TODO )
+PATCHES=( "${FILESDIR}"/${PN}-0.95.8-configure_default_search_paths.patch )
+
+src_prepare() {
+   # Fix some paths
+   for file in WindowMaker/*menu* util/wmgenmenu.c; do
+   if [[ -r $file ]] ; then
+   sed -i -e 
"s|/usr/local/GNUstep/Applications/WPrefs.app|${EPREFIX}/usr/bin/|g;" "$file" 
|| die
+   sed -i -e 
"s|/usr/local/share/WindowMaker|${EPREFIX}/usr/share/WindowMaker|g;" "$file" || 
die
+   sed -i -e 
"s|/opt/share/WindowMaker|${EPREFIX}/usr/share/WindowMaker|g;" "$file" || die
+   fi;
+   done;
+
+   default
+   eautoreconf
+}
+
+src_configure() {
+   local myconf
+
+   # image format types
+   myconf="$(use_enable imagemagick magick) $(use_enable jpeg) 
$(use_enable gif) $(use_enable png) $(use_enable tiff) $(use_enable webp) 
$(use_enable xpm)"
+
+   # non required X capabilities
+   myconf="${myconf} $(use_enable modelock) $(use_enable xrandr randr) 
$(use_enable xinerama)"
+
+   if use nls; then
+   [[ -z $LINGUAS ]] && export LINGUAS="$(ls po/*.po | sed 
's:po/\(.*\)\.po$:\1:' | xargs)"
+   else
+   myconf="${myconf} --disable-locale"
+   fi
+
+   # default settings with $myconf appended
+   econf \
+   --sysconfdir="${EPREFIX}"/etc/X11 \
+   --with-x \
+   --enable-usermenu \
+   --with-pixmapdir="${EPREFIX}"/usr/share/pixmaps \
+   --localedir="${EPREFIX}"/usr/share/locale \
+   ${myconf}
+
+   pushd ../WindowMaker-extra-0.1 || die
+ 

[gentoo-commits] repo/gentoo:master commit in: x11-wm/windowmaker/

2020-04-07 Thread Bernard Cafarelli
commit: ee77889271e873b45b9bafe53c82eaa9eca6922a
Author: Bernard Cafarelli  gentoo  org>
AuthorDate: Tue Apr  7 15:48:27 2020 +
Commit: Bernard Cafarelli  gentoo  org>
CommitDate: Tue Apr  7 15:48:27 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=ee778892

x11-wm/windowmaker: sync live ebuild

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Bernard Cafarelli  gentoo.org>

 x11-wm/windowmaker/windowmaker-.ebuild | 24 
 1 file changed, 12 insertions(+), 12 deletions(-)

diff --git a/x11-wm/windowmaker/windowmaker-.ebuild 
b/x11-wm/windowmaker/windowmaker-.ebuild
index 18bfa9f85a4..7078f87e042 100644
--- a/x11-wm/windowmaker/windowmaker-.ebuild
+++ b/x11-wm/windowmaker/windowmaker-.ebuild
@@ -1,7 +1,7 @@
-# Copyright 1999-2019 Gentoo Authors
+# Copyright 1999-2020 Gentoo Authors
 # Distributed under the terms of the GNU General Public License v2
 
-EAPI=6
+EAPI=7
 inherit autotools eutils git-r3
 
 DESCRIPTION="The fast and light GNUstep window manager"
@@ -32,6 +32,9 @@ DEPEND="media-libs/fontconfig
 RDEPEND="${DEPEND}
nls? ( >=sys-devel/gettext-0.10.39 )"
 
+DOCS=( AUTHORS BUGFORM BUGS ChangeLog INSTALL INSTALL-WMAKER FAQ
+   NEWS README README.definable-cursor README.i18n TODO )
+
 src_unpack() {
# wm-extras
unpack ${A}
@@ -43,9 +46,9 @@ src_prepare() {
# Fix some paths
for file in WindowMaker/*menu* util/wmgenmenu.c; do
if [[ -r $file ]] ; then
-   sed -i -e 
"s:/usr/local/GNUstep/Applications/WPrefs.app:${EPREFIX}/usr/bin/:g;" "$file" 
|| die
-   sed -i -e 
"s:/usr/local/share/WindowMaker:${EPREFIX}/usr/share/WindowMaker:g;" "$file" || 
die
-   sed -i -e 
"s:/opt/share/WindowMaker:${EPREFIX}/usr/share/WindowMaker:g;" "$file" || die
+   sed -i -e 
"s|/usr/local/GNUstep/Applications/WPrefs.app|${EPREFIX}/usr/bin/|g;" "$file" 
|| die
+   sed -i -e 
"s|/usr/local/share/WindowMaker|${EPREFIX}/usr/share/WindowMaker|g;" "$file" || 
die
+   sed -i -e 
"s|/opt/share/WindowMaker|${EPREFIX}/usr/share/WindowMaker|g;" "$file" || die
fi;
done;
 
@@ -77,7 +80,7 @@ src_configure() {
--localedir="${EPREFIX}"/usr/share/locale \
${myconf}
 
-   cd ../WindowMaker-extra-0.1
+   pushd ../WindowMaker-extra-0.1 || die
econf
 }
 
@@ -85,18 +88,15 @@ src_compile() {
emake
 
# WindowMaker Extra Package (themes and icons)
-   cd ../WindowMaker-extra-0.1
+   pushd ../WindowMaker-extra-0.1 || die
emake
 }
 
 src_install() {
-   emake DESTDIR="${D}" install
-
-   dodoc AUTHORS BUGFORM BUGS ChangeLog INSTALL* FAQ* \
- README* NEWS TODO
+   default
 
# WindowMaker Extra
-   cd ../WindowMaker-extra-0.1
+   pushd ../WindowMaker-extra-0.1 || die
emake DESTDIR="${D}" install
 
newdoc README README.extra



[gentoo-commits] repo/gentoo:master commit in: net-libs/librsync/files/, net-libs/librsync/

2020-04-07 Thread Bernard Cafarelli
commit: e28b02899c01823dbec2d41261a1b532f5077f65
Author: Bernard Cafarelli  gentoo  org>
AuthorDate: Tue Apr  7 15:17:33 2020 +
Commit: Bernard Cafarelli  gentoo  org>
CommitDate: Tue Apr  7 15:17:41 2020 +
URL:https://gitweb.gentoo.org/repo/gentoo.git/commit/?id=e28b0289

net-libs/librsync: drop old stable

Package-Manager: Portage-2.3.96, Repoman-2.3.22
Signed-off-by: Bernard Cafarelli  gentoo.org>

 net-libs/librsync/Manifest |  1 -
 .../files/librsync-0.9.7-fix-testsuite.patch   | 15 -
 .../files/librsync-0.9.7-format-security.patch | 20 
 .../librsync/files/librsync-0.9.7-getopt.patch | 17 --
 .../librsync/files/librsync-0.9.7-huge-files.patch | 31 ---
 .../librsync-0.9.7-implicit-declaration.patch  | 19 
 net-libs/librsync/librsync-0.9.7-r3.ebuild | 36 --
 7 files changed, 139 deletions(-)

diff --git a/net-libs/librsync/Manifest b/net-libs/librsync/Manifest
index 1ba8bce2c89..04758c6b00f 100644
--- a/net-libs/librsync/Manifest
+++ b/net-libs/librsync/Manifest
@@ -1,4 +1,3 @@
-DIST librsync-0.9.7.tar.gz 453802 BLAKE2B 
0f8a7a758d847498876401aa04473946970be0257dc0cc4abce85adc7adb5d480d7a41e03d43f667e44ec646ce74a75dfa6b0c63c7f239338244b67eb432e31f
 SHA512 
339362fd01c94411849d3e4a6e95db1bef6cffa0475b1af49d73f11be0421a12d4c73ecbf1a272af01b2a21cec81b4a801c1f7d735e107d0242707fb4c45f9ef
 DIST librsync-2.0.1.tar.gz 169765 BLAKE2B 
3b3a109307dc03e567338709f1c3958a2ae7887165208848359677305f6a983edc1bc71c721dd3f414f77e0507426ae5bb59b9fde51595a92379227ac316127a
 SHA512 
70c1ed0f3a8ad8c1201ce67b5411c4aabb4c78ba9d60e4ee658d9a8818c6511322abd53b583869b8927a29b0f105e1a5c9b05efa748eb435e8fc3b7be3344e04
 DIST librsync-2.0.2.tar.gz 174480 BLAKE2B 
e77d554ad08a852459fe2798249f47ca7f26849b4b8622c5b64f7f9b6d23f1fedc443f747c7988679a3548ea1f6fd2902c424717faaf73a5cfd7e19012a2d72d
 SHA512 
5d2bc1d62b37e9ed7416203615d0a0e3c05c4c884b5da63eda10dd5c985845b500331bce226e4d45676729382c85b41528282e25d491afda31ba434ac0fefad7
 DIST librsync-2.1.0.tar.gz 175630 BLAKE2B 
effd2a8c79fae202921220db7581be1d9f7d278e6ee5155a23e586d9d4a7a27bbc4a50049ddca3b187a8e08451c6dcde7340d22be9fde0c2c12462392043fd8e
 SHA512 
9b91f4b696c1d1cdacb5c0679c7df7a92641e0a6a599c2e5de2bc0af3052b2045bb16c40b072c40859074d792c78c57afb0817917fa9843b179befa4506ebf04

diff --git a/net-libs/librsync/files/librsync-0.9.7-fix-testsuite.patch 
b/net-libs/librsync/files/librsync-0.9.7-fix-testsuite.patch
deleted file mode 100644
index e87c3d8f67b..000
--- a/net-libs/librsync/files/librsync-0.9.7-fix-testsuite.patch
+++ /dev/null
@@ -1,15 +0,0 @@
-Description: Fix running tests with the parallel harness
-Author: Andrey Rahmatullin 
-Last-Update: 2013-06-26
-
 a/testsuite/Makefile.am
-+++ b/testsuite/Makefile.am
-@@ -29,7 +29,7 @@ isprefix_driver_LDADD = ../isprefix.o # XXX: should link 
replaced functions
- # failed.  Generally these tests should be ordered so that more basic
- # tests are run first.
- 
--TESTS_ENVIRONMENT = $(SH) $(srcdir)/driver.sh
-+TEST_LOG_COMPILER = $(SH) $(srcdir)/driver.sh
- 
- TESTS = \
-   signature.test mutate.test sources.test isprefix.test   \

diff --git a/net-libs/librsync/files/librsync-0.9.7-format-security.patch 
b/net-libs/librsync/files/librsync-0.9.7-format-security.patch
deleted file mode 100644
index e35980a4d7a..000
--- a/net-libs/librsync/files/librsync-0.9.7-format-security.patch
+++ /dev/null
@@ -1,20 +0,0 @@
-Description: Always use a format string in printf
- Fix the warning: buf.c:216:9: error: format not a string literal and no
- format arguments [-Werror=format-security]
-Author: Andrey Rahmatullin 
-Forwarded: no
-Last-Update: 2012-02-05
-
-diff --git a/buf.c b/buf.c
-index 7f4e7a0..3a83f2b 100644
 a/buf.c
-+++ b/buf.c
-@@ -213,7 +213,7 @@ rs_result rs_file_copy_cb(void *arg, rs_long_t pos, size_t 
*len, void **buf)
- 
- got = fread(*buf, 1, *len, f);
- if (got == -1) {
--rs_error(strerror(errno));
-+rs_error("%s", strerror(errno));
- return RS_IO_ERROR;
- } else if (got == 0) {
- rs_error("unexpected eof on fd%d", fileno(f));

diff --git a/net-libs/librsync/files/librsync-0.9.7-getopt.patch 
b/net-libs/librsync/files/librsync-0.9.7-getopt.patch
deleted file mode 100644
index 0859089b970..000
--- a/net-libs/librsync/files/librsync-0.9.7-getopt.patch
+++ /dev/null
@@ -1,17 +0,0 @@
-Patch by Daniel Baumann  for librsync >= 0.9.7, which makes
-rdiff aware of -i and -z getopt options mentioned in --help output. For further
-information, please have a look to Debian bug ID #435894.
-
 librsync-0.9.7/rdiff.c 2004-09-17 23:35:50.0 
+0200
-+++ librsync-0.9.7/rdiff.c.getopt  2008-12-20 13:45:58.0 
+0100
-@@ -97,8 +97,8 @@
- { "sum-size",'S', POPT_ARG_INT,  _len },
- { "statistics",  's', POPT_ARG_NONE, _stats },
- { "stats",0,  

  1   2   3   >