summaryrefslogtreecommitdiff
path: root/parallel
AgeCommit message (Collapse)AuthorFilesLines
2014-05-29Bump for perl-5.20.0.wiz8-15/+16
Do it for all packages that * mention perl, or * have a directory name starting with p5-*, or * depend on a package starting with p5- like last time, for 5.18, where this didn't lead to complaints. Let me know if you have any this time.
2014-05-22Add a sge option for openmpimanu3-5/+15
2014-05-17Bump applications PKGREVISIONs for python users that might be usingwiz1-2/+2
python3, since the default changed from python33 to python34. I probably bumped too many. I hope I got them all.
2014-05-05Recursive revbump from x11/pixmanryoon2-3/+4
Fix PR pkg/48777
2014-04-23Force iconv/intl linking. Fixes at least SunOS builds.fhajny1-1/+3
2014-04-19Updated to latest release 3.3.17. Remove py26 incompatibility directive.rodent2-8/+6
This seems to have been fixed in a previous version. At least "import billiard" works from the interpreter. From CHANGES.txt: - Fixes SemLock on Python 3.4 (Issue #107) when using ``forking_enable(False)``. - Pool: Include more useful exitcode information when processes exit.
2014-03-19limits.h is needed for PATH_MAX on FreeBSD too.asau2-5/+5
2014-03-12Python is only a build dependency actually.asau1-2/+3
2014-03-11Remove example rc.d scripts from PLISTs.jperkin1-3/+1
These are now handled dynamically if INIT_SYSTEM is set to "rc.d", or ignored otherwise.
2014-02-20Use PLIST.py2x as provided by the infrastructure.rodent2-10/+3
2014-02-19GCC_REQD should be appended to, not set.jperkin1-2/+2
Fixes issues where a newer GCC has been chosen by the user but the GCC_REQD was forcing an older (and broken) one to be pulled regardless.
2014-02-18Newer NetBSD has shm_open, use a common PLIST fragment for all systemsjoerg3-5/+7
using it.
2014-02-18Updated to latest release, 3.3.0.16. Some important changes to note:rodent3-26/+29
1) The shared library isn't installed with py33. The package uses a pure python implementation; 2) The connection and reduction functions are installed in different directory names depending on python major version. From CHANGES.txt: 3.3.0.16 - 2014-02-11 --------------------- - Previous release was missing the billiard.py3 package from MANIFEST so the installation would not work on Python 3. 3.3.0.15 - 2014-02-10 --------------------- - Pool: Fixed "cannot join process not started" error. - Now uses billiard.py2 and billiard.py3 specific packages that are installed depending on the python version used. This way the installation will not import version specific modules (and possibly crash). 3.3.0.14 - 2014-01-17 --------------------- - Fixed problem with our backwards compatible ``bytes`` wrapper (Issue #103). - No longer expects frozen applications to have a valid ``__file__`` attribute.
2014-02-12Recursive PKGREVISION bump for OpenSSL API version bump.tron3-4/+6
2014-01-22Fix: dsh should read config file from sysconfdir but example directorycheusov3-17/+5
2014-01-19Fix PLIST for python-3.x. Remove FETCH_USING, not package-setable.wiz2-4/+3
2014-01-17Mark as PYTHON_VERSIONS_INCOMPATIBLE=26:wiz1-1/+3
SyntaxError: ('invalid syntax', ('/usr/pkg/lib/python2.6/site-packages/billiard/_connection3.py', 851, 47, ' _ready_errors = {_winapi.ERROR_BROKEN_PIPE, _winapi.ERROR_NETNAME_DELETED}\n'))
2014-01-17Treat FreeBSD as other BSD systems.asau3-7/+9
2014-01-14Update to sge 8.1.6markd11-384/+165
Version 8.1.6 ------------- * Bug fixes Version 8.1.5 ------------- * Bug fixes Version 8.1.4 ------------- Milestone version: over 1000 patches since the last from Sun * Bug fixes * Enhancements * qacct: print category information; support -A like -P ; make -u a synonym for -o; -E selects on job end times read from standard input with -f * Move manager/operator setup in startup scripts * Installation creates an environment modules file * Add monitor_qmaster.sh script * Write shepherd panic messages to syslog, not into /tmp * Add .desktop file for qmon * rpm/dpkg packaging allows building against motif (recent Debian/Fedora) * Accounting reports qmaster-enforced resource limits (only on master PE task if accounting_summary is false) * Add "smp" to the default queue PE list * install_execd doesn't check the presence of (mostly irrelevant) binaries * Add configuration for logcheck * Potentially incompatible changes * renew_all_certs.ksh re-named to renew_all_certs.sh * Expand $ja_task_id to 0 for non-array jobs * Move manager/operator setup in startup scripts * For security reasons, installation defaults for min_uid, min_gid in sge_conf(5) are now 100 without CSP. See <http://arc.liv.ac.uk/SGE/howto/sge-security.html> * RPM layout changed to put relevant ones under noarch (on RHEL6 and recent Fedora), with a separate guiinst package * Memory values can be input and output in TB or tB (possible incompatibility parsing output) * Reduce execd CPU time reading large smaps files from Linux /proc and provide USE_SMAPS in execd_params to turn it on (default now off because huge smaps are generated by some programs) * Remove redundant -verify option from qsh, qlogin (per doc) Version 8.1.3 ------------- * Bug fixes * Enhancements * Document Interix building explicitly * qstat reports array task maximum concurrency * qstatus removes [] suffix for non-array jobs if -t was requested * Read /etc/default/{sgeexecd,sgemaster} to allow customizing rc scripts * Location of daemon pid files can be specified with SGE_QMASTER_PIDFILE, SGE_EXECD_PIDFILE * Debian packaging (as an add-on, installing into /opt/sge) * Expand $sge_root and $sge_cell in the definitions of prolog and similar methods * Check in init script that shepherd will load * Add lx-armhf architecture * On Linux and NetBSD, report jobs' virtual memory usage as accurately as possible * Add -nobincheck installation option to avoid checking binaries * Add some build hooks, useful for Debian particularly. * Potentially incompatible changes * qacct prints units (might affect parsing the output) * Correct spelling of "comunication_error" in qstat XML error output * Fix problems submitting to ARs (printing times now doesn't use a days field in qstat etc.) * Java version >= 1.5 required * Lower default MAX_DYN_EC somewhat to avoid warning on typical Linux configurations * Other changes * Don't install the ckpt directory (contents obsolete) Version 8.1.2 ------------- * Bug fixes * Enhancements * Use cpusets for process containment on fairly recent Linux-based systems (see USE_CGROUPS in sge_conf(5)) * Add bootstrap build script * Make SGE template an RPM conf file * Incompatible changes * Make CRL and certificate expiry consistent Version 8.1.1 ------------- * Bug fixes * Security * Don't pass any user environment to remote startup daemons -- better fix for half of CVE-2012-0208 * Enhancements * SGE_BINDING is set in the environment for all types of binding * New jobstats(1) provides historical job summary * Berkeleydb spools can optionally be opened "private" to allow operation on NFS3 filesystems. Currently no installer support, but see bootstrap(5) and the health warning * Environment variable SGE_DRMAA_ALLOW_JOB_ERROR_STATE allows DRMAA jobs to enter the error state; see drmaa_submit(3) * Define SGE_JOBEXIT_STAT environment variable in epilog; see submit(1) * The user from which mail is sent can be configured in sge_conf(5) * Topology items are now static load values; see load_parameters(5) * qstat now prints array job dependency info * Default to support for qsort_args in sge_pe(5) * Include an example of logrotate usage * Install an "smp" PE * Distribute/document sge_share_mon(1) to print share tree * Improve install template defaults * GPU load sensor (dist/util/resources/loadsensors/gpu-loadsensor.c) * Allow building Kerberos/GSSAPI security modules against Heimdal (but GSS is still not properly usable) * Support arm and mipsel on GNU/Linux, completing the set of official Debian Linux-based ports * Support for OpenBSD (untested) * Preliminary support for Cygwin: everything builds, clients work (lightly tested), daemons need fixing * Add ja_task_id to expandable variables in ckpt_command and similar methods * distinst supports installation with install(1) for use with -local * Incompatible changes * The CA directory is now /var/lib/sgeCA instead of /var/sgeCA but installation will offer to move it [fixme] * Drop (any pretence at) support for Cray/Unicos, NEC SX, Darwin 6 * The spool format for parallel job tasks has changed from any previous version built with qsort_args (as above), which will make live upgrades from such a version fail on nodes running parallel jobs * Other changes * Extensive internal changes to improve robustness, e.g. of string-handling against buffer overruns -- somewhat error-prone and may have caused regressions; more required * Install script allows rsh et al to be omitted from binary distribution in favour of ssh Version 8.1.0 ------------- * Security fix * Prevent users other than root deleting entries with sgepasswd * Version numbering * Switch to a more logical numbering scheme now that the Univa baseline is irrelevant * Bug fixes * Other changes * Hadoop support now for a more recent Hadoop distribution (see README.BUILD) Version 8.0.0e -------------- Mostly build and security issues * Bug fixes * Security fixes The first fix is for a trivial remote root by a valid user. The others, including fixes for potential buffer overruns in daemon and setuid programs, may or may not be exploitable. * Sanitize the environment before executing remote startup programs etc. Somewhat incompatible: LD_LIBRARY_PATH etc. may need to be set differently. See the security notes in remote_startup(5) and sge_conf(5). (CVE-2012-0208, thanks to William Hay) * Don't write initial log messages in /tmp. Somewhat incompatible: initial messages now in syslog. * Avoid using mktemp. (Probably not a significant problem.) * Control core dumps under setuid etc. with SGE_ENABLE_COREDUMP. (Not normally a security issue.) * Bounds checking in replace_params * Avoid execd crash and possible overruns * Fixes for buffer overrun and other improvements for (setuid program) sgepasswd
2014-01-12morr@ dropped maintainershipcheusov1-2/+2
2014-01-11Revbump after updating tcl/tk.adam2-4/+4
2014-01-10+ dshcheusov1-1/+2
2014-01-10Add parallel/dsh packagecheusov5-0/+53
dsh is an implementation of a wrapper for executing multiple remote shell (rsh/remsh/ssh) commands. rsh/remsh/ssh are wrappers for executing shell (ksh/bash/zsh/tcsh/sh .. etc... ) on remote hosts.
2014-01-10Add and enable package "pdsh"cheusov5-1/+53
2013-12-31Needs USE_LANGUAGES+=c to compile C extensions and shared library. Fixesrodent1-1/+2
build on NetBSD-6.0/i386, likely.
2013-12-31Updated to latest release, 3.3.0.13. Note changes to some files in therodent3-8/+21
PLIST. From ChangeLog: 3.3.0.13 - 2013-12-13 --------------------- - Fixes compatability with Python < 2.7.6 - No longer attempts to handle ``SIGBUS`` - Non-thread based pool now only handles signals: ``SIGHUP``, ``SIGQUIT``, ``SIGTERM``, ``SIGUSR1``, ``SIGUSR2``. - setup.py: Only show compilation warning for build related commands. 3.3.0.12 - 2013-12-09 --------------------- - Fixed installation for Python 3. - Pool: Fixed bug with maxtasksperchild. - Pool: Fixed bug in maintain_pool. 3.3.0.11 - 2013-12-03 --------------------- - Fixed Unicode error when installing the distribution (Issue #89). - Daemonic processes are now allowed to have children. But note that it will not be possible to automatically terminate them when the process exits. - Pool: Would not always be able to detect that a process exited. 3.3.0.10 - 2013-12-02 --------------------- - Windows: Fixed problem with missing ``WAITABANDONED_0`` - Windows: PipeConnection can now be inherited. 3.3.0.9 - 2013-12-02 -------------------- - Temporary workaround for Celery maxtasksperchild issue. 3.3.0.8 - 2013-11-21 -------------------- - Now also sets ``multiprocessing.current_process`` for compatibility with loggings ``processName`` field. 3.3.0.7 - 2013-11-15 -------------------- - Fixed compatibility with PyPy 2.1 + 2.2. - Fixed problem in pypy detection. - Now uses ``ctypes.find_library`` instead of hardcoded path to find the OS X CoreServices framework. 3.3.0.6 - 2013-11-12 -------------------- - Now works without C extension again. - New ``_billiard.read(fd, buffer, [len, ])` function implements os.read with buffer support (new buffer API) - New pure-python implementation of ``Connection.send_offset``. 3.3.0.5 - 2013-11-11 -------------------- - All platforms except for Windows/PyPy/Jython now requires the C extension. 3.3.0.4 - 2013-11-11 -------------------- - Fixed problem with Python3 and setblocking. 3.3.0.3 - 2013-11-09 -------------------- - Now works on Windows again. 3.3.0.2 - 2013-11-08 -------------------- - ApplyResult.terminate() may be set to signify that the job must not be executed. It can be used in combination with Pool.terminate_job. - Pipe/_SimpleQueue: Now supports rnonblock/wnonblock arguments to set the read or write end of the pipe to be nonblocking. - Pool: Log message included exception info but exception happened in another process so the resulting traceback was wrong. - Pool: Worker process can now prepare results before they are sent back to the main process (using ``Worker.prepare_result``). 3.3.0.1 - 2013-11-04 -------------------- - Pool: New ``correlation_id`` argument to ``apply_async`` can be used to set a related id for the ``ApplyResult`` object returned: >>> r = pool.apply_async(target, args, kwargs, correlation_id='foo') >>> r.correlation_id 'foo' - Pool: New callback `on_process_exit` is called when a pool process exits, with signature ``(pid, exitcode)``. - Pool: Improved the too many restarts detection. 3.3.0.0 - 2013-10-14 -------------------- - Dual code base now runs on Python 2.6+ and Python 3. - No longer compatible with Python 2.5 - Includes many changes from multiprocessing in 3.4. - Now uses ``time.monotonic`` when available, also including fallback implementations for Linux and OS X. - No longer cleans up after receiving SIGILL, SIGSEGV or SIGFPE - ``Finalize`` and ``register_after_fork`` is now aliases to multiprocessing. It's better to import these from multiprocessing directly now so that there aren't multiple registries. - New `billiard.queues._SimpleQueue` that does not use semaphores. - Pool: Can now be extended to support using multiple IPC queues. - Pool: Can now use async I/O to write to pool IPC queues. - Pool: New ``Worker.on_loop_stop`` handler can be used to add actions at pool worker process shutdown. Note that, like all finalization handlers, there is no guarantee that this will be executed.
2013-12-28Define _KMEMUSER for NetBSD 6.99.asau2-1/+17
2013-12-17POSIX shmem module is installed on FreeBSD.asau1-0/+3
2013-12-17No utmp.h on modern FreeBSD, use utmpx.h instead.asau3-6/+35
2013-12-06Update to SLURM 2.6.4asau21-50/+248
Based on work of Jason Bacon published in WIP. * Changes in Slurm 2.6.4 ======================== -- Fixed sh5util to print its usage. -- Corrected commit f9a3c7e4e8ec. -- Honor ntasks-per-node option with exclusive node allocations. -- sched/backfill - Prevent invalid memory reference if bf_continue option is configured and slurm is reconfigured during one of the sleep cycles or if there are any changes to the partition configuration or if the normal scheduler runs and starts a job that the backfill scheduler is actively working on. -- Update man pages information about acct-freq and JobAcctGatherFrequency to reflect only the latest supported format. -- Minor document update to include note about PrivateData=Usage for the slurm.conf when using the DBD. -- Expand information reported with DebugFlags=backfill. -- Initiate jobs pending to run in a reservation as soon as the reservation becomes active. -- Purged expired reservation even if it has pending jobs. -- Corrections to calculation of a pending job's expected start time. -- Remove some vestigial logic treating job priority of 1 as a special case. -- Memory freeing up to avoid minor memory leaks at close of daemons -- Updated documentation to give correct units being displayed. -- Report AccountingStorageBackupHost with "scontrol show config". -- init scripts ignore quotes around Pid file name specifications. -- Fixed typo about command case in quickstart.html. -- task/cgroup - handle new cpuset files, similar to commit c4223940. -- Replace the tempname() function call with mkstemp(). -- Fix for --cpu_bind=map_cpu/mask_cpu/map_ldom/mask_ldom plus --mem_bind=map_mem/mask_mem options, broken in 2.6.2. -- Restore default behavior of allocating cores to jobs on a cyclic basis across the sockets unless SelectTypeParameters=CR_CORE_DEFAULT_DIST_BLOCK or user specifies other distribution options. -- Enforce JobRequeue configuration parameter on node failure. Previously always requeued the job. -- acct_gather_energy/ipmi - Add delay before retry on read error. -- select/cons_res with GRES and multiple threads per core, fix possible infinite loop. -- proctrack/cgroup - Add cgroup create retry logic in case one step is starting at the same time as another step is ending and the logic to create and delete cgroups overlaps. -- Improve setting of job wait "Reason" field. -- Correct sbatch documentation and job_submit/pbs plugin "%j" is job ID, not "%J" (which is job_id.step_id). -- Improvements to sinfo performance, especially for large numbers of partitions. -- SlurmdDebug - Permit changes to slurmd debug level with "scontrol reconfig" -- smap - Avoid invalid memory reference with hidden nodes. -- Fix sacctmgr modify qos set preempt+/-=. -- BLUEGENE - fix issue where node count wasn't set up correctly when srun preforms the allocation, regression in 2.6.3. -- Add support for dependencies of job array elements (e.g. "sbatch --depend=afterok:123_4 ...") or all elements of a job array (e.g. "sbatch --depend=afterok:123 ..."). -- Add support for new options in sbatch qsub wrapper: -W block=true (wait for job completion) Clear PBS_NODEFILE environment variable -- Fixed the MaxSubmitJobsPerUser limit in QOS which limited submissions a job too early. -- sched/wiki, sched/wiki2 - Fix to work with change logic introduced in version 2.6.3 preventing Maui/Moab from starting jobs. -- Updated the QOS limits documentation and man page. * Changes in Slurm 2.6.3 ======================== -- Add support for some new #PBS options in sbatch scripts and qsub wrapper: -l accelerator=true|false (GPU use) -l mpiprocs=# (processors per node) -l naccelerators=# (GPU count) -l select=# (node count) -l ncpus=# (task count) -v key=value (environment variable) -W depend=opts (job dependencies, including "on" and "before" options) -W umask=# (set job's umask) -- Added qalter and qrerun commands to torque package. -- Corrections to qstat logic: job CPU count and partition time format. -- Add job_submit/pbs plugin to translate PBS job dependency options to the extend possible (no support for PBS "before" options) and set some PBS environment variables. -- Add spank/pbs plugin to set a bunch of PBS environment variables. -- Backported sh5util from master to 2.6 as there are some important bugfixes and the new item extraction feature. -- select/cons_res - Correct MacCPUsPerNode partition constraint for CR_Socket. -- scontrol - for setdebugflags command, avoid parsing "-flagname" as an scontrol command line option. -- Fix issue with step accounting if a job is requeued. -- Close file descriptors on exec of prolog, epilog, etc. -- Fix issue when a user has held a job and then sets the begin time into the future. -- Scontrol - Enable changing a job's stdout file. -- Fix issues where memory or node count of a srun job is altered while the srun is pending. The step creation would use the old values and possibly hang srun since the step wouldn't be able to be created in the modified allocation. -- Add support for new SchedulerParameters value of "bf_max_job_part", the maximum depth the backfill scheduler should go in any single partition. -- acct_gather/infiniband plugin - Correct packets_in/out values. -- BLUEGENE - Don't ignore a conn-type request from the user. -- BGQ - Force a request on a Q for a MESH to be a TORUS in a dimension that can only be a TORUS (1). -- Change max message length from 100MB to 1GB before generating "Insane message length" error. -- sched/backfill - Prevent possible memory corruption due to use of bf_continue option and long running scheduling cycle (pending jobs could have been cancelled and purged). -- CRAY - fix AcceleratorAllocation depth correctly for basil 1.3 -- Created the environment variable SLURM_JOB_NUM_NODES for srun jobs and updated the srun man page. -- BLUEGENE/CRAY - Don't set env variables that pertain to a node when Slurm isn't doing the launching. -- gres/gpu and gres/mic - Do not treat the existence of an empty gres.conf file as a fatal error. -- Fixed for if hours are specified as 0 the time days-0:min specification is not parsed correctly. -- switch/nrt - Fix for memory leak. -- Subtract the PMII_COMMANDLEN_SIZE in contribs/pmi2/pmi2_api.c to prevent certain implementation of snprintf() to segfault. * Changes in Slurm 2.6.2 ======================== -- Fix issue with reconfig and GrpCPURunMins -- Fix of wrong node/job state problem after reconfig -- Allow users who are coordinators update their own limits in the accounts they are coordinators over. -- BackupController - Make sure we have a connection to the DBD first thing to avoid it thinking we don't have a cluster name. -- Correct value of min_nodes returned by loading job information to consider the job's task count and maximum CPUs per node. -- If running jobacct_gather/none fix issue on unpacking step completion. -- Reservation with CoreCnt: Avoid possible invalid memory reference. -- sjstat - Add man page when generating rpms. -- Make sure GrpCPURunMins is added when creating a user, account or QOS with sacctmgr. -- Fix for invalid memory reference due to multiple free calls caused by job arrays submitted to multiple partitions. -- Enforce --ntasks-per-socket=1 job option when allocating by socket. -- Validate permissions of key directories at slurmctld startup. Report anything that is world writable. -- Improve GRES support for CPU topology. Previous logic would pick CPUs then reject jobs that can not match GRES to the allocated CPUs. New logic first filters out CPUs that can not use the GRES, next picks CPUs for the job, and finally picks the GRES that best match those CPUs. -- Switch/nrt - Prevent invalid memory reference when allocating single adapter per node of specific adapter type -- CRAY - Make Slurm work with CLE 5.1.1 -- Fix segfault if submitting to multiple partitions and holding the job. -- Use MAXPATHLEN instead of the hardcoded value 1024 for maximum file path lengths. -- If OverTimeLimit is defined do not declare failed those jobs that ended in the OverTimeLimit interval. * Changes in Slurm 2.6.1 ======================== -- slurmdbd - Allow job derived ec and comments to be modified by non-root users. -- Fix issue with job name being truncated to 24 chars when sending a mail message. -- Fix minor issues with spec file, missing files and including files erroneously on a bluegene system. -- sacct - fix --name and --partition options when using accounting_storage/filetxt. -- squeue - Remove extra whitespace of default printout. -- BGQ - added head ppcfloor as an include dir when building. -- BGQ - Better debug messages in runjob_mux plugin. -- PMI2 Updated the Makefile.am to build a versioned library. -- CRAY - Fix srun --mem_bind=local option with launch/aprun. -- PMI2 Corrected buffer size computation in the pmi2_api.c module. -- GRES accounting data wrong in database: gres_alloc, gres_req, and gres_used fields were empty if the job was not started immediately. -- Fix sbatch and srun task count logic when --ntasks-per-node specified, but no explicit task count. -- Corrected the hdf5 profile user guide and the acct_gather.conf documentation. -- IPMI - Fix Math bug getting new wattage. -- Corrected the AcctGatherProfileType documentation in slurm.conf -- Corrected the sh5util program to print the header in the csv file only once, set the debug messages at debug() level, make the argument check case insensitive and avoid printing duplicate \n. -- If cannot collect energy values send message to the controller to drain the node and log error slurmd log file. -- Handle complete removal of CPURunMins time at the end of the job instead of at multifactor poll. -- sview - Add missing debug_flag options. -- PGSQL - Notes about Postgres functionality being removed in the next version of Slurm. -- MYSQL - fix issue when rolling up usage and events happened when a cluster was down (slurmctld not running) during that time period. -- sched/wiki2 - Insure that Moab gets current CPU load information. -- Prevent infinite loop in parsing configuration if including file containing one blank line. -- Fix pack and unpack between 2.6 and 2.5. -- Fix job state recovery logic in which a job's accounting frequency was not set. This would result in a value of 65534 seconds being used (the equivalent of NO_VAL in uint16_t), which could result in the job being requeued or aborted. -- Validate a job's accounting frequency at submission time rather than waiting for it's initiation to possibly fail. -- Fix CPURunMins if a job is requeued from a failed launch. -- Fix in accounting_storage/filetxt to correct start times which sometimes could end up before the job started. -- Fix issue with potentially referencing past an array in parse_time() -- CRAY - fix issue with accelerators on a cray when parsing BASIL 1.3 XML. -- Fix issue with a 2.5 slurmstepd locking up when talking to a 2.6 slurmd. -- Add argument to priority plugin's priority_p_reconfig function to note when the association and QOS used_cpu_run_secs field has been reset. * Changes in Slurm 2.6.0 ======================== -- Fix it so bluegene and serial systems don't get warnings over new NODEDATA enum. -- When a job is aborted send a message for any tasks that have completed. -- Correction to memory per CPU calculation on system with threads and allocating cores or sockets. -- Requeue batch job if it's node reboots (used to abort the job). -- Enlarge maximum size of srun's hostlist file. -- IPMI - Fix first poll to get correct consumed_energy for a step. -- Correction to job state recovery logic that could result in assert failure. -- Record partial step accounting record if allocated nodes fail abnormally. -- Accounting - fix issue where PrivateData=jobs or users could potentially show information to users that had no associations on the system. -- Make PrivateData in slurmdbd.conf case insensitive. -- sacct/sstat - Add format option ConsumedEnergyRaw to print full energy values. * Changes in Slurm 2.6.0rc2 =========================== -- HDF5 - Fix issue with Ubuntu where HDF5 development headers are overwritten by the parallel versions thus making it so we need handle both cases. -- ACCT_GATHER - handle suspending correctly for polling threads. -- Make SLURM_DISTRIBUTION env var hold both types of distribution if specified. -- Remove hardcoded /usr/local from slurm.spec. -- Modify slurmctld locking to improve performance under heavy load with very large numbers of batch job submissions or job cancellations. -- sstat - Fix issue where if -j wasn't given allow last argument to be checked for as the job/step id. -- IPMI - fix adjustment on poll when using EnergyIPMICalcAdjustment. * Changes in Slurm 2.6.0rc1 =========================== -- Added helper script for launching symmetric and MIC-only MPI tasks within SLURM (in contribs/mic/mpirun-mic). -- Change maximum delay for state save from 2 secs to 5 secs. Make timeout configurable at build time by defining SAVE_MAX_WAIT. -- Modify slurmctld data structure locking to interleave read and write locks rather than always favor write locks over read locks. -- Added sacct format option of "ALL" to print all fields. -- Deprecate the SchedulerParameters value of "interval" use "bf_interval" instead as documented. -- Add acct_gather_profile/hdf5 to profile jobs with hdf5 -- Added MaxCPUsPerNode partition configuration parameter. This can be especially useful to schedule systems with GPUs. -- Permit "scontrol reboot_node" for nodes in MAINT reservation. -- Added "PriorityFlags" value of "SMALL_RELATIVE_TO_TIME". If set, the job's size component will be based upon not the job size alone, but the job's size divided by it's time limit. -- Added sbatch option "--ignore-pbs" to ignore "#PBS" options in the batch script. -- Rename slurm_step_ctx_params_t field from "mem_per_cpu" to "pn_min_memory". Job step now accepts memory specification in either per-cpu or per-node basis. -- Add ability to specify host repitition count in the srun hostfile (e.g. "host1*2" is equivalent to "host1,host1"). * Changes in Slurm 2.6.0pre3 ============================ -- Add milliseconds to default log message header (both RFC 5424 and ISO 8601 time formats). Disable milliseconds logging using the configure parameter "--disable-log-time-msec". Default time format changes to ISO 8601 (without time zone information). Specify "--enable-rfc5424time" to restore the time zone information. -- Add username (%u) to the filename pattern in the batch script. -- Added options for front end nodes of AllowGroups, AllowUsers, DenyGroups, and DenyUsers. -- Fix sched/backfill logic to initiate jobs with maximum time limit over the partition limit, but the minimum time limit permits it to start. -- gres/gpu - Fix for gres.conf file with multiple files on a single line using a slurm expression (e.g. "File=/dev/nvidia[0-1]"). -- Replaced ipmi.conf with generic acct_gather.conf file for all acct_gather plugins. For those doing development to use this follow the model set forth in the acct_gather_energy_ipmi plugin. -- Added more options to update a step's information -- Add DebugFlags=ThreadID which will print the thread id of the calling thread. -- CRAY - Allocate whole node (CPUs) in reservation despite what the user requests. We have found any srun/aprun afterwards will work on a subset of resources. * Changes in Slurm 2.6.0pre2 ============================ -- Do not purge inactive interactive jobs that lack a port to ping (added for MR+ operation). -- Advanced reservations with hostname and core counts now supports asymetric reservations (e.g. specific different core count for each node). -- Added slurmctld/dynalloc plugin for MapReduce+ support. -- Added "DynAllocPort" configuration parameter. -- Added partition paramter of SelectTypeParameters to override system-wide value. -- Added cr_type to partition_info data structure. -- Added allocated memory to node information available (within the existing select_nodeinfo field of the node_info_t data structure). Added Allocated Memory to node information displayed by sview and scontrol commands. -- Make sched/backfill the default scheduling plugin rather than sched/builtin (FIFO). -- Added support for a job having different priorities in different partitions. -- Added new SchedulerParameters configuration parameter of "bf_continue" which permits the backfill scheduler to continue considering jobs for backfill scheduling after yielding locks even if new jobs have been submitted. This can result in lower priority jobs from being backfill scheduled instead of newly arrived higher priority jobs, but will permit more queued jobs to be considered for backfill scheduling. -- Added support to purge reservation records from accounting. -- Cray - Add support for Basil 1.3 * Changes in SLURM 2.6.0pre1 ============================ -- Add "state" field to job step information reported by scontrol. -- Notify srun to retry step creation upon completion of other job steps rather than polling. This results in much faster throughput for job step execution with --exclusive option. -- Added "ResvEpilog" and "ResvProlog" configuration parameters to execute a program at the beginning and end of each reservation. -- Added "slurm_load_job_user" function. This is a variation of "slurm_load_jobs", but accepts a user ID argument, potentially resulting in substantial performance improvement for "squeue --user=ID" -- Added "slurm_load_node_single" function. This is a variation of "slurm_load_nodes", but accepts a node name argument, potentially resulting in substantial performance improvement for "sinfo --nodes=NAME". -- Added "HealthCheckNodeState" configuration parameter identify node states on which HealthCheckProgram should be executed. -- Remove sacct --dump --formatted-dump options which were deprecated in 2.5. -- Added support for job arrays (phase 1 of effort). See "man sbatch" option -a/--array for details. -- Add new AccountStorageEnforce options of 'nojobs' and 'nosteps' which will allow the use of accounting features like associations, qos and limits but not keep track of jobs or steps in accounting. -- Cray - Add new cray.conf parameter of "AlpsEngine" to specify the communication protocol to be used for ALPS/BASIL. -- select/cons_res plugin: Correction to CPU allocation count logic in for cores without hyperthreading. -- Added new SelectTypeParameter value of "CR_ALLOCATE_FULL_SOCKET". -- Added PriorityFlags value of "TICKET_BASED" and merged priority/multifactor2 plugin into priority/multifactor plugin. -- Add "KeepAliveTime" configuration parameter controlling how long sockets used for srun/slurmstepd communications are kept alive after disconnect. -- Added SLURM_SUBMIT_HOST to salloc, sbatch and srun job environment. -- Added SLURM_ARRAY_TASK_ID to environment of job array. -- Added squeue --array/-r option to optimize output for job arrays. -- Added "SlurmctldPlugstack" configuration parameter for generic stack of slurmctld daemon plugins. -- Removed contribs/arrayrun tool. Use native support for job arrays. -- Modify default installation locations for RPMs to match "make install": _prefix /usr/local _slurm_sysconfdir %{_prefix}/etc/slurm _mandir %{_prefix}/share/man _infodir %{_prefix}/share/info -- Add acct_gather_energy/ipmi which works off freeipmi for energy gathering * Changes in Slurm 2.5.8 ======================== -- Fix for slurmctld segfault on NULL front-end reason field. -- Avoid gres step allocation errors when a job shrinks in size due to either down nodes or explicit resizing. Generated slurmctld errors of this type: "step_test ... gres_bit_alloc is NULL" -- Fix bug that would leak memory and over-write the AllowGroups field if on "scontrol reconfig" when AllowNodes is manually changed using scontrol. -- Get html/man files to install in correct places with rpms. -- Remove --program-prefix from spec file since it appears to be added by default and appeared to break other things. -- Updated the automake min version in autogen.sh to be correct. -- Select/cons_res - Correct total CPU count allocated to a job with --exclusive and --cpus-per-task options -- switch/nrt - Don't allocate network resources unless job step has 2+ nodes. -- select/cons_res - Avoid extraneous "oversubscribe" error messages. -- Reorder get config logic to avoid deadlock. -- Enforce QOS MaxCPUsMin limit when job submission contains no user-specified time limit. -- EpilogSlurmctld pthread is passed required arguments rather than a pointer to the job record, which under some conditions could be purged and result in an invalid memory reference. * Changes in Slurm 2.5.7 ======================== -- Fix for linking to the select/cray plugin to not give warning about undefined variable. -- Add missing symbols to the xlator.h -- Avoid placing pending jobs in AdminHold state due to backfill scheduler interactions with advanced reservation. -- Accounting - make average by task not cpu. -- CRAY - Change logging of transient ALPS errors from error() to debug(). -- POE - Correct logic to support poe option "-euidevice sn_all" and "-euidevice sn_single". -- Accounting - Fix minor initialization error. -- POE - Correct logic to support srun network instances count with POE. -- POE - With the srun --launch-cmd option, report proper task count when the --cpus-per-task option is used without the --ntasks option. -- POE - Fix logic binding tasks to CPUs. -- sview - Fix race condition where new information could of slipped past the node tab and we didn't notice. -- Accounting - Fix an invalid memory read when slurmctld sends data about start job to slurmdbd. -- If a prolog or epilog failure occurs, drain the node rather than setting it down and killing all of its jobs. -- Priority/multifactor - Avoid underflow in half-life calculation. -- POE - pack missing variable to allow fanout (more than 32 nodes) -- Prevent clearing reason field for pending jobs. This bug was introduced in v2.5.5 (see "Reject job at submit time ..."). -- BGQ - Fix issue with preemption on sub-block jobs where a job would kill all preemptable jobs on the midplane instead of just the ones it needed to. -- switch/nrt - Validate dynamic window allocation size. -- BGQ - When --geo is requested do not impose the default conn_types. -- CRAY - Support CLE 4.2.0 -- RebootNode logic - Defers (rather than forgets) reboot request with job running on the node within a reservation. -- switch/nrt - Correct network_id use logic. Correct support for user sn_all and sn_single options. -- sched/backfill - Modify logic to reduce overhead under heavy load. -- Fix job step allocation with --exclusive and --hostlist option. -- Select/cons_res - Fix bug resulting in error of "cons_res: sync loop not progressing, holding job #" -- checkpoint/blcr - Reset max_nodes from zero to NO_VAL on job restart. -- launch/poe - Fix for hostlist file support with repeated host names. -- priority/multifactor2 - Prevent possible divide by zero. -- srun - Don't check for executable if --test-only flag is used. -- energy - On a single node only use the last task for gathering energy. Since we don't currently track energy usage per task (only per step). Otherwise we get double the energy. * Changes in Slurm 2.5.6 ======================== -- Gres fix for requeued jobs. -- Gres accounting - Fix regression in 2.5.5 for keeping track of gres requested and allocated. * Changes in Slurm 2.5.5 ======================== -- Fix for sacctmgr add qos to handle the 'flags' option. -- Export SLURM_ environment variables from sbatch, even if "--export" option does not explicitly list them. -- If node is in more than one partition, correct counting of allocated CPUs. -- If step requests more CPUs than possible in specified node count of job allocation then return ESLURM_TOO_MANY_REQUESTED_CPUS rather than ESLURM_NODES_BUSY and retrying. -- CRAY - Fix SLURM_TASKS_PER_NODE to be set correctly. -- Accounting - more checks for strings with a possible `'` in it. -- sreport - Fix by adding planned down time to utilization reports. -- Do not report an error when sstat identifies job steps terminated during its execution, but log using debug type message. -- Select/cons_res - Permit node removed from job by going down to be returned to service and re-used by another job. -- Select/cons_res - Tighter packing of job allocations on sockets. -- SlurmDBD - fix to allow user root along with the slurm user to register a cluster. -- Select/cons_res - Fix for support of consecutive node option. -- Select/cray - Modify build to enable direct use of libslurm library. -- Bug fixes related to job step allocation logic. -- Cray - Disable enforcement of MaxTasksPerNode, which is not applicable with launch/aprun. -- Accounting - When rolling up data from past usage ignore "idle" time from a reservation when it has the "Ignore_Jobs" flag set. Since jobs could run outside of the reservation in it's nodes without this you could have double time. -- Accounting - Minor fix to avoid reuse of variable erroneously. -- Reject job at submit time if the node count is invalid. Previously such a job submitted to a DOWN partition would be queued. -- Purge vestigial job scripts when the slurmd cold starts or slurmstepd terminates abnormally. -- Add support for FreeBSD. -- Add sanity check for NULL cluster names trying to register. -- BGQ - Push action 'D' info to scontrol for admins. -- Reset a job's reason from PartitionDown when the partition is set up. -- BGQ - Handle issue where blocks would have a pending job on them and while it was free cnodes would go into software error and kill the job. -- BGQ - Fix issue where if for some reason we are freeing a block with a pending job on it we don't kill the job. -- BGQ - Fix race condition were a job could of been removed from a block without it still existing there. This is extremely rare. -- BGQ - Fix for when a step completes in Slurm before the runjob_mux notifies the slurmctld there were software errors on some nodes. -- BGQ - Fix issue on state recover if block states are not around and when reading in state from DB2 we find a block that can't be created. You can now do a clean start to rid the bad block. -- Modify slurmdbd to retransmit to slurmctld daemon if it is not responding. -- BLUEGENE - Fix issue where when doing backfill preemptable jobs were never looked at to determine eligibility of backfillable job. -- Cray/BlueGene - Disable srun --pty option unless LaunchType=launch/slurm. -- CRAY - Fix sanity check for systems with more than 32 cores per node. -- CRAY - Remove other objects from MySQL query that are available from the XML. -- BLUEGENE - Set the geometry of a job when a block is picked and the job isn't a sub-block job. -- Cray - avoid check of macro versions of CLE for version 5.0. -- CRAY - Fix memory issue with reading in the cray.conf file. -- CRAY - If hostlist is given with srun make sure the node count is the same as the hosts given. -- CRAY - If task count specified, but no tasks-per-node, then set the tasks per node in the BASIL reservation request. -- CRAY - fix issue with --mem option not giving correct amount of memory per cpu. -- CRAY - Fix if srun --mem is given outside an allocation to set the APRUN_DEFAULT_MEMORY env var for aprun. This scenario will not display the option when used with --launch-cmd. -- Change sview to use GMutex instead of GStaticMutex -- CRAY - set APRUN_DEFAULT_MEMROY instead of CRAY_AUTO_APRUN_OPTIONS -- sview - fix issue where if a partition was completely in one state the cpu count would be reflected correctly. -- BGQ - fix for handling half rack system in STATIC of OVERLAP mode to implicitly create full system block. -- CRAY - Dynamically create BASIL XML buffer to resize as needed. -- Fix checking if QOS limit MaxCPUMinsPJ is set along with DenyOnLimit to deny the job instead of holding it. -- Make sure on systems that use a different launcher than launch/slurm not to attempt to signal tasks on the frontend node. -- Cray - when a step is requested count other steps running on nodes in the allocation as taking up the entire node instead of just part of the node allocated. And always enforce exclusive on a step request. -- Cray - display correct nodelist, node/cpu count on steps. * Changes in Slurm 2.5.4 ======================== -- Fix bug in PrologSlurmctld use that would block job steps until node responds. -- CRAY - If a partition has MinNodes=0 and a batch job doesn't request nodes put the allocation to 1 instead of 0 which prevents the allocation to happen. -- Better debug when the database is down and using the --cluster option in the user commands. -- When asking for job states with sacct, default to 'now' instead of midnight of the current day. -- Fix for handling a test-only job or immediate job that fails while being built. -- Comment out all of the logic in the job_submit/defaults plugin. The logic is only an example and not meant for actual use. -- Eliminate configuration file 4096 character line limitation. -- More robust logic for tree message forward -- BGQ - When cnodes fail in a timeout fashion correctly look up parent midplane. -- Correct sinfo "%c" (node's CPU count) output value for Bluegene systems. -- Backfill - Responsive improvements for systems with large numbers of jobs (>5000) and using the SchedulerParameters option bf_max_job_user. -- slurmstepd: ensure that IO redirection openings from/to files correctly handle interruption -- BGQ - Able to handle when midplanes go into Hardware::SoftwareFailure -- GRES - Correct tracking of specific resources used after slurmctld restart. Counts would previously go negative as jobs terminate and decrement from a base value of zero. -- Fix for priority/multifactor2 plugin to not assert when configured with --enable-debug. -- Select/cons_res - If the job request specified --ntasks-per-socket and the allocation using is cores, then pack the tasks onto the sockets up to the specified value. -- BGQ - If a cnode goes into an 'error' state and the block containing the cnode does not have a job running on it do not resume the block. -- BGQ - Handle blocks that don't free themselves in a reasonable time better. -- BGQ - Fix for signaling steps when allocation ends before step. -- Fix for backfill scheduling logic with job preemption; starts more jobs. -- xcgroup - remove bugs with EINTR management in write calls -- jobacct_gather - fix total values to not always == the max values. -- Fix for handling node registration messages from older versions without energy data. -- BGQ - Allow user to request full dimensional mesh. -- sdiag command - Correction to jobs started value reported. -- Prevent slurmctld assert when invalid change to reservation with running jobs is made. -- BGQ - If signal is NODE_FAIL allow forward even if job is completing and timeout in the runjob_mux trying to send in this situation. -- BGQ - More robust checking for correct node, task, and ntasks-per-node options in srun, and push that logic to salloc and sbatch. -- GRES topology bug in core selection logic fixed. -- Fix to handle init.d script for querying status and not return 1 on success. * Changes in SLURM 2.5.3 ======================== -- Gres/gpu plugin - If no GPUs requested, set CUDA_VISIBLE_DEVICES=NoDevFiles. This bug was introduced in 2.5.2 for the case where a GPU count was configured, but without device files. -- task/affinity plugin - Fix bug in CPU masks for some processors. -- Modify sacct command to get format from SACCT_FORMAT environment variable. -- BGQ - Changed order of library inclusions and fixed incorrect declaration to compile correctly on newer compilers -- Fix for not building sview if glib exists on a system but not the gtk libs. -- BGQ - Fix for handling a job cleanup on a small block if the job has long since left the system. -- Fix race condition in job dependency logic which can result in invalid memory reference. * Changes in SLURM 2.5.2 ======================== -- Fix advanced reservation recovery logic when upgrading from version 2.4. -- BLUEGENE - fix for QOS/Association node limits. -- Add missing "safe" flag from print of AccountStorageEnforce option. -- Fix logic to optimize GRES topology with respect to allocated CPUs. -- Add job_submit/all_partitions plugin to set a job's default partition to ALL available partitions in the cluster. -- Modify switch/nrt logic to permit build without libnrt.so library. -- Handle srun task launch failure without duplicate error messages or abort. -- Fix bug in QoS limits enforcement when slurmctld restarts and user not yet added to the QOS list. -- Fix issue where sjstat and sjobexitmod was installed in 2 different RPMs. -- Fix for job request of multiple partitions in which some partitions lack nodes with required features. -- Permit a job to use a QOS they do not have access to if an administrator manually set the job's QOS (previously the job would be rejected). -- Make more variables available to job_submit/lua plugin: slurm.MEM_PER_CPU, slurm.NO_VAL, etc. -- Fix topology/tree logic when nodes defined in slurm.conf get re-ordered. -- In select/cons_res, correct logic to allocate whole sockets to jobs. Work by Magnus Jonsson, Umea University. -- In select/cons_res, correct logic when job removed from only some nodes. -- Avoid apparent kernel bug in 2.6.32 which apparently is solved in at least 3.5.0. This avoids a stack overflow when running jobs on more than 120k nodes. -- BLUEGENE - If we made a block that isn't runnable because of a overlapping block, destroy it correctly. -- Switch/nrt - Dynamically load libnrt.so from within the plugin as needed. This eliminates the need for libnrt.so on the head node. -- BLUEGENE - Fix in reservation logic that could cause abort. * Changes in SLURM 2.5.1 ======================== -- Correction to hostlist sorting for hostnames that contain two numeric components and the first numeric component has various sizes (e.g. "rack9blade1" should come before "rack10blade1") -- BGQ - Only poll on initialized blocks instead of calling getBlocks on each block independently. -- Fix of task/affinity plugin logic for Power7 processors having hyper- threading disabled (cpu mask has gaps). -- Fix of job priority ordering with sched/builtin and priority/multifactor. Patch from Chris Read. -- CRAY - Fix for setting up the aprun for a large job (+2000 nodes). -- Fix for race condition related to compute node boot resulting in node being set down with reason of "Node <name> unexpectedly rebooted" -- RAPL - Fix for handling errors when opening msr files. -- BGQ - Fix for salloc/sbatch to do the correct allocation when asking for -N1 -n#. -- BGQ - in emulation make it so we can pretend to run large jobs (>64k nodes) -- BLUEGENE - Correct method to update conn_type of a job. -- BLUEGENE - Fix issue with preemption when needing to preempt multiple jobs to make one job run. -- Fixed issue where if an srun dies inside of an allocation abnormally it would of also killed the allocation. -- FRONTEND - fixed issue where if a systems nodes weren't defined in the slurm.conf with NodeAddr's signals going to a step could be handled incorrectly. -- If sched/backfill starts a job with a QOS having NO_RESERVE and not job time limit, start it with the partition time limit (or one year if the partition has no time limit) rather than NO_VAL (140 year time limit); -- Alter hostlist logic to allocate large grid dynamically instead of on stack. -- Change RPC version checks to support version 2.5 slurmctld with version 2.4 slurmd daemons. -- Correct core reservation logic for use with select/serial plugin. -- Exit scontrol command on stdin EOF. -- Disable job --exclusive option with select/serial plugin. * Changes in SLURM 2.5.0 ======================== -- Add DenyOnLimit flag for QOS to deny jobs at submission time if they request resources that reach a 'Max' limit. -- Permit SlurmUser or operator to change QOS of non-pending jobs (e.g. running jobs). -- BGQ - move initial poll to beginning of realtime interaction, which will also cause it to run if the realtime server ever goes away. * Changes in SLURM 2.5.0-rc2 ============================ -- Modify sbcast logic to survive slurmd daemon restart while file a transmission is in progress. -- Add retry logic to munge encode/decode calls. This is needed if the munge deamon is under very heavy load (e.g. with 1000 slurmd daemons per compute node). -- Add launch and acct_gather_energy plugins to RPMs. -- Restore support for srun "--mpi=list" option. -- CRAY - Introduce step accounting for a Cray. -- Modify srun to abandon I/O 60 seconds after the last task ends. Otherwise an aborted slurmstepd can cause the srun process to hang indefinitely. -- ENERGY - RAPL - alter code to close open files (and only open them once where needed) -- If the PrologSlurmctld fails, then requeue the job an indefinite number of times instead of only one time. * Changes in SLURM 2.5.0-rc1 ============================ -- Added Prolog and Epilog Guide (web page). Based upon work by Jason Sollom, Cray Inc. and used by permission. -- Restore gang scheduling functionality. Preemptor was not being scheduled. Fix for bugzilla #3. -- Add "cpu_load" to node information. Populate CPULOAD in node information reported to Moab cluster manager. -- Preempt jobs only when insufficient idle resources exist to start job, regardless of the node weight. -- Added priority/multifactor2 plugin based upon ticket distribution system. Work by Janne Blomqvist, Aalto University. -- Add SLURM_NODELIST to environment variables available to Prolog and Epilog. -- Permit reservations to allow or deny access by account and/or user. -- Add ReconfigFlags value of KeepPartState. See "man slurm.conf" for details. -- Modify the task/cgroup plugin adding a task_pre_launch_priv function and move slurmstepd outside of the step's cgroup. Work by Matthieu Hautreux. -- Intel MIC processor support added using gres/mic plugin. BIG thanks to Olli-Pekka Lehto, CSC-IT Center for Science Ltd. -- Accounting - Change empty jobacctinfo structs to not actually be used instead of putting 0's into the database we put NO_VALS and have sacct figure out jobacct_gather wasn't used. -- Cray - Prevent calling basil_confirm more than once per job using a flag. -- Fix bug with topology/tree and job with min-max node count. Now try to get max node count rather than minimizing leaf switches used. -- Add AccountingStorageEnforce=safe option to provide method to avoid jobs launching that wouldn't be able to run to completion because of a GrpCPUMins limit. -- Add support for RFC 5424 timestamps in logfiles. Disable with configuration option of "--disable-rfc5424time". By Janne Blomqvist, Aalto University. -- CRAY - Replace srun.pl with launch/aprun plugin to use srun to wrap the aprun process instead of a perl script. -- srun - Rename --runjob-opts to --launcher-opts to be used on systems other than BGQ. -- Added new DebugFlags - Energy for AcctGatherEnergy plugins. -- start deprecation of sacct --dump --fdump -- BGQ - added --verbose=OFF when srun --quiet is used -- Added acct_gather_energy/rapl plugin to record power consumption by job. Work by Yiannis Georgiou, Martin Perry, et. al., Bull * Changes in SLURM 2.5.0.pre3 ============================= -- Add Google search to all web pages. -- Add sinfo -T option to print reservation information. Work by Bill Brophy, Bull. -- Force slurmd exit after 2 minute wait, even if threads are hung. -- Change node_req field in struct job_resources from 8 to 32 bits so we can run more than 256 jobs per node. -- sched/backfill: Improve accuracy of expected job start with respect to reservations. -- sinfo partition field size will be set the the length of the longest partition name by default. -- Make it so the parse_time will return a valid 0 if given epoch time and set errno == ESLURM_INVALID_TIME_VALUE on error instead. -- Correct srun --no-alloc logic when node count exceeds node list or task task count is not a multiple of the node count. Work by Hongjia Cao, NUDT. -- Completed integration with IBM Parallel Environment including POE and IBM's NRT switch library. * Changes in SLURM 2.5.0.pre2 ============================= -- When running with multiple slurmd daemons per node, enable specifying a range of ports on a single line of the node configuration in slurm.conf. -- Add reservation flag of Part_Nodes to allocate all nodes in a partition to a reservation and automatically change the reservation when nodes are added to or removed from the reservation. Based upon work by Bill Brophy, Bull. -- Add support for advanced reservation for specific cores rather than whole nodes. Current limiations: homogeneous cluster, nodes idle when reservation created, and no more than one reservation per node. Code is still under development. Work by Alejandro Lucero Palau, et. al, BSC. -- Add DebugFlag of Switch to log switch plugin details. -- Correct job node_cnt value in job completion plugin when job fails due to down node. Previously was too low by one. -- Add new srun option --cpu-freq to enable user control over the job's CPU frequency and thus it's power consumption. NOTE: cpu frequency is not currently preserved for jobs being suspended and later resumed. Work by Don Albert, Bull. -- Add node configuration information about "boards" and optimize task placement on minimum number of boards. Work by Rod Schultz, Bull. * Changes in SLURM 2.5.0.pre1 ============================= -- Add new output to "scontrol show configuration" of LicensesUsed. Output is "name:used/total" -- Changed jobacct_gather plugin infrastructure to be cleaner and easier to maintain. -- Change license option count separator from "*" to ":" for consistency with the gres option (e.g. "--licenses=foo:2 --gres=gpu:2"). The "*" will still be accepted, but is no longer documented. -- Permit more than 100 jobs to be scheduled per node (new limit is 250 jobs). -- Restructure of srun code to allow outside programs to utilize existing logic. * Changes in SLURM 2.4.6 ======================== -- Correct WillRun authentication logic when issued for non-job owner. -- BGQ - fix memory leak -- BGQ - Fix to check block for action 'D' if it also has nodes in error. * Changes in SLURM 2.4.5 ======================== -- Cray - On job kill requeust, send SIGCONT, SIGTERM, wait KillWait and send SIGKILL. Previously just sent SIGKILL to tasks. -- BGQ - Fix issue when running srun outside of an allocation and only specifying the number of tasks and not the number of nodes. -- BGQ - validate correct ntasks_per_node -- BGQ - when srun -Q is given make runjob be quiet -- Modify use of OOM (out of memory protection) for Linux 2.6.36 kernel or later. NOTE: If you were setting the environment variable SLURMSTEPD_OOM_ADJ=-17, it should be set to -1000 for Linux 2.6.36 kernel or later. -- BGQ - Fix job step timeout actually happen when done from within an allocation. -- Reset node MAINT state flag when a reservation's nodes or flags change. -- Accounting - Fix issue where QOS usage was being zeroed out on a slurmctld restart. -- BGQ - Add 64 tasks per node as a valid option for srun when used with overcommit. -- BLUEGENE - With Dynamic layout mode - Fix issue where if a larger block was already in error and isn't deallocating and underlying hardware goes bad one could get overlapping blocks in error making the code assert when a new job request comes in. -- BGQ - handle pending actions on a block better when trying to deallocate it. -- Accounting - Fixed issue where if nodenames have changed on a system and you query against that with -N and -E you will get all jobs during that time instead of only the ones running on -N. -- BGP - Fix for HTC mode -- Accounting - If a job start message fails to the SlurmDBD reset the db_inx so it gets sent again. This isn't a major problem since the start will happen when the job ends, but this does make things cleaner. -- If an salloc is waiting for an allocation to happen and is canceled by the user mark the state canceled instead of completed. -- Fix issue in accounting if a user puts a '\' in their job name. -- Accounting - Fix for if asking for users or accounts that were deleted with associations get the deleted associations as well. -- BGQ - Handle shared blocks that need to be removed and have jobs running on them. This should only happen in extreme conditions. -- Fix inconsistency for hostlists that have more than 1 range. -- BGQ - Add mutex around recovery for the Real Time server to avoid hitting DB2 so hard. -- BGQ - If an allocation exists on a block that has a 'D' action on it fail job on future step creation attempts. * Changes in SLURM 2.4.4 ======================== -- BGQ - minor fix to make build work in emulated mode. -- BGQ - Fix if large block goes into error and the next highest priority jobs are planning on using the block. Previously it would fail those jobs erroneously. -- BGQ - Fix issue when a cnode going to an error (not SoftwareError) state with a job running or trying to run on it. -- Execute slurm_spank_job_epilog when there is no system Epilog configured. -- Fix for srun --test-only to work correctly with timelimits -- BGQ - If a job goes away while still trying to free it up in the database, and the job is running on a small block make sure we free up the correct node count. -- BGQ - Logic added to make sure a job has finished on a block before it is purged from the system if its front-end node goes down. -- Modify strigger so that a filter option of "--user=0" is supported. -- Correct --mem-per-cpu logic for core or socket allocations with multiple threads per core. -- Fix for older < glibc 2.4 systems to use euidaccess() instead of eaccess(). -- BLUEGENE - Do not alter a pending job's node count when changing it's partition. -- BGQ - Add functionality to make it so we track the actions on a block. This is needed for when a free request is added to a block but there are jobs finishing up so we don't start new jobs on the block since they will fail on start. -- BGQ - Fixed InactiveLimit to work correctly to avoid scenarios where a user's pending allocation was started with srun and then for some reason the slurmctld was brought down and while it was down the srun was removed. -- Fixed InactiveLimit math to work correctly -- BGQ - Add logic to make it so blocks can't use a midplane with a nodeboard in error for passthrough. -- BGQ - Make it so if a nodeboard goes in error any block using that midplane for passthrough gets removed on a dynamic system. -- BGQ - Fix for printing realtime server debug correctly. -- BGQ - Cleaner handling of cnode failures when reported through the runjob interface instead of through the normal method. -- smap - spread node information across multiple lines for larger systems. -- Cray - Defer salloc until after PrologSlurmctld completes. -- Correction to slurmdbd communications failure handling logic, incorrect error codes returned in some cases. * Changes in SLURM 2.4.3 ======================== -- Accounting - Fix so complete 32 bit numbers can be put in for a priority. -- cgroups - fix if initial directory is non-existent SLURM creates it correctly. Before the errno wasn't being checked correctly -- BGQ - fixed srun when only requesting a task count and not a node count to operate the same way salloc or sbatch did and assign a task per cpu by default instead of task per node. -- Fix salloc --gid to work correctly. Reported by Brian Gilmer -- BGQ - fix smap to set the correct default MloaderImage -- BLUEGENE - updated documentation. -- Close the batch job's environment file when it contains no data to avoid leaking file descriptors. -- Fix sbcast's credential to last till the end of a job instead of the previous 20 minute time limit. The previous behavior would fail for large files 20 minutes into the transfer. -- Return ESLURM_NODES_BUSY rather than ESLURM_NODE_NOT_AVAIL error on job submit when required nodes are up, but completing a job or in exclusive job allocation. -- Add HWLOC_FLAGS so linking to libslurm works correctly -- BGQ - If using backfill and a shared block is running at least one job and a job comes through backfill and can fit on the block without ending jobs don't set an end_time for the running jobs since they don't need to end to start the job. -- Initialize bind_verbose when using task/cgroup. -- BGQ - Fix for handling backfill much better when sharing blocks. -- BGQ - Fix for making small blocks on first pass if not sharing blocks. -- BLUEGENE - Remove force of default conn_type instead of leaving NAV when none are requested. The Block allocator sets it up temporarily so this isn't needed. -- BLUEGENE - Fix deadlock issue when dealing with bad hardware if using static blocks. -- Fix to mysql plugin during rollup to only query suspended table when jobs reported some suspended time. -- Fix compile with glibc 2.16 (Kacper Kowalik) -- BGQ - fix for deadlock where a block has error on it and all jobs running on it are preemptable by scheduling job. -- proctrack/cgroup: Exclude internal threads from "scontrol list pids". Patch from Matthieu Hautreux, CEA. -- Memory leak fixed for select/linear when preempting jobs. -- Fix if updating begin time of a job to update the eligible time in accounting as well. -- BGQ - make it so you can signal steps when signaling the job allocation. -- BGQ - Remove extra overhead if a large block has many cnode failures. -- Priority/Multifactor - Fix issue with age factor when a job is estimated to start in the future but is able to run now. -- CRAY - update to work with ALPS 5.1 -- BGQ - Handle issue of speed and mutexes when polling instead of using the realtime server. -- BGQ - Fix minor sorting issue with sview when sorting by midplanes. -- Accounting - Fix for handling per user max node/cpus limits on a QOS correctly for current job. -- Update documentation for -/+= when updating a reservation's users/accounts/flags -- Update pam module to work if using aliases on nodes instead of actual host names. -- Correction to task layout logic in select/cons_res for job with minimum and maximum node count. -- BGQ - Put final poll after realtime comes back into service to avoid having the realtime server go down over and over again while waiting for the poll to finish. -- task/cgroup/memory - ensure that ConstrainSwapSpace=no is correctly handled. Work by Matthieu Hautreux, CEA. -- CRAY - Fix for sacct -N option to work correctly -- CRAY - Update documentation to describe installation from rpm instead or previous piecemeal method. -- Fix sacct to work with QOS' that have previously been deleted. -- Added all available limits to the output of sacctmgr list qos * Changes in SLURM 2.4.2 ======================== -- BLUEGENE - Correct potential deadlock issue when hardware goes bad and there are jobs running on that hardware. -- If job is submitted to more than one partition, it's partition pointer can be set to an invalid value. This can result in the count of CPUs allocated on a node being bad, resulting in over- or under-allocation of its CPUs. Patch by Carles Fenoy, BSC. -- Fix bug in task layout with select/cons_res plugin and --ntasks-per-node option. Patch by Martin Perry, Bull. -- BLUEGENE - remove race condition where if a block is removed while waiting for a job to finish on it the number of unused cpus wasn't updated correctly. -- BGQ - make sure we have a valid block when creating or finishing a step allocation. -- BLUEGENE - If a large block (> 1 midplane) is in error and underlying hardware is marked bad remove the larger block and create a block over just the bad hardware making the other hardware available to run on. -- BLUEGENE - Handle job completion correctly if an admin removes a block where other blocks on an overlapping midplane are running jobs. -- BLUEGENE - correctly remove running jobs when freeing a block. -- BGQ - correct logic to place multiple (< 1 midplane) steps inside a multi midplane block allocation. -- BGQ - Make it possible for a multi midplane allocation to run on more than 1 midplane but not the entire allocation. -- BGL - Fix for syncing users on block from Tim Wickberg -- Fix initialization of protocol_version for some messages to make sure it is always set when sending or receiving a message. -- Reset backfilled job counter only when explicitly cleared using scontrol. Patch from Alejandro Lucero Palau, BSC. -- BLUEGENE - Fix for handling blocks when a larger block will not free and while it is attempting to free underlying hardware is marked in error making small blocks overlapping with the freeing block. This only applies to dynamic layout mode. -- Cray and BlueGene - Do not treat lack of usable front-end nodes when slurmctld deamon starts as a fatal error. Also preserve correct front-end node for jobs when there is more than one front-end node and the slurmctld daemon restarts. -- Correct parsing of srun/sbatch input/output/error file names so that only the name "none" is mapped to /dev/null and not any file name starting with "none" (e.g. "none.o"). -- BGQ - added version string to the load of the runjob_mux plugin to verify the current plugin has been loaded when using runjob_mux_refresh_config -- CGROUPS - Use system mount/umount function calls instead of doing fork exec of mount/umount from Janne Blomqvist. -- BLUEGENE - correct start time setup when no jobs are blocking the way from Mark Nelson -- Fixed sacct --state=S query to return information about suspended jobs current or in the past. -- FRONTEND - Made error warning more apparent if a frontend node isn't configured correctly. -- BGQ - update documentation about runjob_mux_refresh_config which works correctly as of IBM driver V1R1M1 efix 008.
2013-12-01Revbump from devel/apr updateryoon1-2/+2
2013-10-31Fix PKG_USERS usage.jperkin2-4/+6
2013-10-20Don't try to mess with the compiler scheduling.joerg3-3/+17
2013-10-20Fix rpath options to use -Wl prefix.joerg2-8/+8
2013-10-10Recursive revbump from pango-1.36.0ryoon1-2/+2
2013-09-20Remove curl dependency, put file on nbftp.wiz1-2/+1
2013-09-20Updated to latest release. From CHANGES.txt:rodent2-6/+7
2.7.3.32 - 2012-08-16 --------------------- - Fixed compatibility with Python 3.3 - Process boostrap: Now ignores errors while flushing stdout (Issue #16).
2013-09-02Revbump after cairo updateadam1-2/+2
2013-08-26Update to version 0.19.1cheusov2-6/+6
paexec: Fix for segfault seen on Linux
2013-08-25Update to 0.19.0cheusov4-42/+28
This release of paexec was successfully tested on the following platforms: NetBSD-6.1/amd64, OpenBSD-5.3/i386, FreeBSD-8.3/i386, Solaris-10/sparc, Solaris-11/amd64 and diverse Linux/{i386,amd64}. paexec is now selfcontained, libmaa is not needed anymore. Presentation paexec.pdf was added to presentation/. I hope it will help easier understand how "paexec" works. It is installed to ${DOCDIR}. paexec: - POSIX-2008 getline(3) is used for reading lines instead of home-made function. - t '' is equivalent to "no transport", spaces are trimmed. - "-n +NNN" has higher priority than -t, i.e. if they both are specified, transport is ignored. - Fix for -W1. - Environment variable PAEXEC_EOT was introduced. - Option -y was added to paexec(1) and paexec_reorder(1). - Option -C was added to paexec(1). paexec_reorder: - Option -x was added to paexec_reorder(1). A number of fixes and improvements in regression tests.
2013-07-28Update to 2.7.3.31:wiz2-7/+6
2.7.3.31 - 2012-07-04 --------------------- - Recent changes broke support for running without C extension (Issue #57).
2013-07-19Add f90 option for fortran90 bindingsmanu3-4/+25
2013-07-16Update to hwloc-1.7.1manu2-8/+8
Changes since 1.7 from NEWS file: Version 1.7.1 ------------- * Fix a failed assertion in the distance grouping code when loading a XML file that already contains some groups. Thanks to Laercio Lima Pilla for reporting the problem. * Remove unexpected Group objects when loading XML topologies with I/O objects and NUMA distances. Thanks to Elena Elkina for reporting the problem and testing patches. * Fix PCI link speed discovery when using libpciaccess. * Fix invalid libpciaccess virtual function device/vendor IDs when using SR-IOV PCI devices on Linux. * Fix GL component build with old NVCtrl releases. Thanks to Jirka Hladky for reporting the problem. * Fix embedding breakage caused by libltdl. Thanks to Pavan Balaji for reporting the problem. * Always use the system-wide libltdl instead of shipping one inside hwloc. * Document issues when enabling plugins while embedding hwloc in another project, in the documentation section Embedding hwloc in Other Software. * Add a FAQ entry "How to get useful topology information on NetBSD?" in the documentation. * Somes fixes in the renaming code for embedding. * Miscellaneous minor build fixes.
2013-07-12Bump PKGREVISION of all packages which create users, to pick up change ofjperkin3-6/+6
sysutils/user_* packages.
2013-07-02+py-billiardrodent1-1/+2
2013-07-02Import py27-billiard-2.7.3.30 as parallel/py-billiard.rodent4-0/+128
billiard is a fork of the Python 2.7 multiprocessing package. The multiprocessing package itself is a renamed and updated version of R Oudkerk's pyprocessing package. This standalone variant is intended to be compatible with Python 2.4 and 2.5, and will draw it's fixes/improvements from python-trunk. * Also it is a fork of the multiprocessin backport package by Christian Heims; * It includes the no-execv patch contributed by R. Oudkerk; * And the Pool improvements previously located in Celery;
2013-06-16This package doesn't contain Fortran code and doesn't use Fortran libraries.asau1-2/+2
2013-06-16Fix build with perl-5.18.wiz2-1/+54
2013-06-06Bump PKGREVISION for libXft changes for NetBSD native X support onwiz1-2/+2
NetBSD 6, requested by tron.
2013-06-04Try to fix the fallout caused by the fix for PR pkg/47882. Part 3:tron2-4/+4
Recursively bump package revisions again after the "freetype2" and "fontconfig" handling was fixed.