Eucalyptus Configuration Variables

Eucalyptus exposes a number of variables that can be configured using the command. This topic explains what types of variables Eucalyptus uses, and lists the most common configurable variables.

Eucalyptus Variable Types

Eucalyptus uses two types of variables: ones that can be changed (as configuration options), and ones that cannot be changed (they are displayed as variables, but configured by modifying the eucalyptus.conf file on the CC).

Eucalyptus Variables

The following table contains a list of common Eucalyptus cloud variables.

VariableDescription
authentication.access_keys_limitLimit for access keys per user
authentication.authorization_cacheAuthorization cache configuration, for credentials and authorization metadata
authentication.authorization_expiryDefault expiry for cached authorization metadata
authentication.authorization_reuse_expiryDefault expiry for re-use of cached authorization metadata on failure
authentication.credential_download_generate_certificateStrategy for generation of certificates on credential download (Never
authentication.credential_download_host_matchCIDR to match against for host address selection
authentication.credential_download_portPort to use in service URLs when ‘bootstrap.webservices.port’ is not appropriate.
authentication.default_password_expiryDefault password expiry time
authentication.max_policy_attachmentsMaximum number of attached managed policies
authentication.max_policy_sizeMaximum size for an IAM policy (bytes)
authentication.signing_certificates_limitLimit for signing certificates per user
authentication.system_account_quota_enabledProcess quotas for system accounts
autoscaling.activityexpiryExpiry age for scaling activities. Older activities are deleted.
autoscaling.activityinitialbackoffInitial back-off period for failing activities.
autoscaling.activitymaxbackoffMaximum back-off period for failing activities.
autoscaling.activitytimeoutTimeout for a scaling activity.
autoscaling.maxlaunchincrementMaximum instances to launch at one time.
autoscaling.maxregistrationretriesNumber of times to attempt load balancer registration for each instance.
autoscaling.maxtagsMaximum number of user defined tags for a group
autoscaling.pendinginstancetimeoutTimeout for a pending instance.
autoscaling.suspendedprocessesGlobally suspend scaling processes; a comma-delimited list of processes (Launch,Terminate,HealthCheck, ReplaceUnhealthy,AZRebalance, AlarmNotification,ScheduledActions, AddToLoadBalancer). Default is empty, meaning the processes are not suspended.
autoscaling.suspendedtasksSuspended scaling tasks.
autoscaling.suspensionlaunchattemptsthresholdMinimum launch attempts for administrative suspension of scaling activities for a group.
autoscaling.suspensiontimeoutTimeout for administrative suspension of scaling activities for a group.
autoscaling.untrackedinstancetimeoutTimeout for termination of untracked auto scaling instances.
autoscaling.zonefailurethresholdTime after which an unavailable zone should be treated as failed
bootstrap.async.future_listener_debug_limit_secsNumber of seconds a future listener can execute before a debug message is logged.
bootstrap.async.future_listener_error_limit_secsNumber of seconds a future listener can execute before an error message is logged.
bootstrap.async.future_listener_get_retriesTotal number of seconds a future listener’s executor waits to get().
bootstrap.async.future_listener_get_timeoutNumber of seconds a future listener’s executor waits to get() per call.
bootstrap.async.future_listener_info_limit_secsNumber of seconds a future listener can execute before an info message is logged.
bootstrap.hosts.state_initialize_timeoutTimeout for state initialization (in msec).
bootstrap.hosts.state_transfer_timeoutTimeout for state transfers (in msec).
bootstrap.notifications.batch_delay_secondsInterval (in seconds) during which a notification will be delayed to allow for batching events for delivery.
bootstrap.notifications.digestSend a system state digest periodically.
bootstrap.notifications.digest_frequency_hoursPeriod (in hours) with which a system state digest will be delivered.
bootstrap.notifications.digest_only_on_errorsIf sending system state digests is set to true, then only send the digest when the system has failures to report.
bootstrap.notifications.digest_frequency_hoursPeriod (in hours) with which a system state digest will be delivered.
bootstrap.notifications.digest_only_on_errorsIf sending system state digests is set to true, then only send the digest when the system has failures to report.
bootstrap.notifications.email_fromFrom email address used for notification delivery.
bootstrap.notifications.email_from_nameFrom email name used for notification delivery.
bootstrap.notifications.email_from_nameFrom email name used for notification delivery.
bootstrap.notifications.email_subject_prefixEmail subject used for notification delivery.
bootstrap.notifications.email_toEmail address where notifications are to be delivered.
bootstrap.notifications.include_fault_stackPeriod (in hours) with which a system state digest will be delivered.
bootstrap.notifications.email.email_smtp_hostSMTP host to use when sending email. If unset, the following values are tried: 1) the value of the ‘mail.smtp.host’ system variable, 2) localhost, 3) mailhost.
bootstrap.notifications.email.email_smtp_portSMTP port to use when sending email. Defaults to 25
bootstrap.servicebus.common_thread_pool_sizeDefault thread pool for component message processing. When the size of the common thread pool is zero or less, Eucalyptus uses separate thread pools for each component and a pool for dispatching. Default size = 256 threads.
bootstrap.servicebus.component_thread_pool_sizeUsed when the size of the common thread pool is zero or less. Default size = 64 threads.
bootstrap.servicebus.context_message_log_whitelistMessage patterns to match for logging. Allows selective message logging at INFO level. A list of wildcards that allows selective logging for development or troubleshooting (e.g., on request/response, on a package, on a component). Logging can impact security; do not use as a general purpose logging feature.
bootstrap.servicebus.context_timeoutMessage context timeout in seconds. Default = 60 seconds.
bootstrap.servicebus.dispatch_thread_pool_sizeUsed when the size of the common thread pool is zero or less. Default size = 256 threads.
bootstrap.servicebus.hupDo a soft reset. Default = 0 (false).
bootstrap.timer.rateAmount of time (in milliseconds) before a previously running instance which is not reported will be marked as terminated.
bootstrap.topology.coordinator_check_backoff_secsBackoff between service state checks (in seconds).
bootstrap.topology.local_check_backoff_secsBackoff between service state checks (in seconds).
bootstrap.tx.concurrent_update_retriesMaximum number of times a transaction may be retried before giving up.
bootstrap.webservices.async_internal_operationsExecute internal service operations from a separate thread pool (with respect to I/O).
bootstrap.webservices.async_operationsExecute service operations from a separate thread pool (with respect to I/O).
bootstrap.webservices.async_pipelineExecute service specific pipeline handlers from a separate thread pool (with respect to I/O).
bootstrap.webservices.channel_connect_timeoutChannel connect timeout (ms).
bootstrap.webservices.channel_keep_aliveSocket keep alive.
bootstrap.webservices.channel_nodelayServer socket TCP_NODELAY.
bootstrap.webservices.channel_reuse_addressSocket reuse address.
bootstrap.webservices.client_http_chunk_buffer_maxServer http chunk max.
bootstrap.webservices.client_http_pool_acquire_timeoutClient http pool acquire timeout
bootstrap.webservices.client_internal_connect_timeout_millisClient connection timeout (ms)
bootstrap.webservices.client_internal_hmac_signature_enabledClient HMAC signature version 4 enabled
bootstrap.webservices.client_internal_timeout_secsClient idle timeout (secs).
bootstrap.webservices.client_message_log_whitelistClient message patterns to match for logging
bootstrap.webservices.client_pool_max_threadsServer worker thread pool max.
bootstrap.webservices.clock_skew_secA max clock skew value (in seconds) between client and server accepted when validating timestamps in Query/REST protocol.
bootstrap.webservices.cluster_connect_timeout_millisCluster connect timeout (ms).
bootstrap.webservices.default_aws_sns_uri_schemeDefault scheme for AWS_SNS_URL.
bootstrap.webservices.default_ec2_uri_schemeDefault scheme for EC2_URL.
bootstrap.webservices.default_euare_uri_schemeDefault scheme for EUARE_URL.
bootstrap.webservices.default_https_enabledDefault scheme prefix.
bootstrap.webservices.default_s3_uri_schemeDefault scheme for S3_URL.
bootstrap.webservices.disabled_soap_api_componentsList of services with disabled SOAP APIs.
bootstrap.webservices.http_max_chunk_bytesMaximum HTTP chunk size (bytes).
bootstrap.webservices.http_max_header_bytesMaximum HTTP headers size (bytes).
bootstrap.webservices.http_max_initial_line_bytesMaximum HTTP initial line size (bytes).
bootstrap.webservices.http_max_requests_per_connectionMaximum HTTP requests per persistent connection
bootstrap.webservices.http_server_headerHTTP server header returned for responses. If set to “default”, the standard version header is returned, e.g. Eucalyptus/4.3.1. If set to another value, that value is returned in the header, except for an empty value, which results in no server header being returned.Default: default
bootstrap.webservices.listener_address_matchCIDRs matching addresses to bind on Default interface is always bound regardless.
bootstrap.webservices.log_requestsEnable request logging.
bootstrap.webservices.oob_internal_operationsExecute internal service operations out of band from the normal service bus.
bootstrap.webservices.pipeline_enable_query_decompressEnable Query Pipeline http request decompression
bootstrap.webservices.pipeline_idle_timeout_secondsServer socket idle time-out.
bootstrap.webservices.pipeline_max_query_request_sizeMaximum Query Pipeline http chunk size (bytes).
bootstrap.webservices.portPort to bind Port 8773 is always bound regardless.
bootstrap.webservices.replay_skew_window_secTime interval duration (in seconds) during which duplicate signatures will be accepted to accommodate collisions.
bootstrap.webservices.server_boss_pool_max_mem_per_connServer max selector memory per connection.
bootstrap.webservices.server_boss_pool_max_threadsServer selector thread pool max.
bootstrap.webservices.server_boss_pool_timeout_millisService socket select timeout (ms).
bootstrap.webservices.server_boss_pool_total_memServer worker thread pool max.
bootstrap.webservices.server_channel_nodelayServer socket TCP_NODELAY.
bootstrap.webservices.server_channel_reuse_addressServer socket reuse address.
bootstrap.webservices.server_pool_max_mem_per_connServer max worker memory per connection.
bootstrap.webservices.server_pool_max_threadsServer worker thread pool max.
bootstrap.webservices.server_pool_timeout_millisService socket select timeout (ms).
bootstrap.webservices.server_pool_total_memServer max worker memory total.
bootstrap.webservices.statisticsRecord and report service times.
bootstrap.webservices.unknown_parameter_handlingRequest unknown parameter handling (default
bootstrap.webservices.use_dns_delegationUse DNS delegation.
bootstrap.webservices.use_instance_dnsUse DNS names for instances.
bootstrap.webservices.ssl.client_https_enabledClient HTTPS enabled
bootstrap.webservices.ssl.client_https_server_cert_verifyClient HTTPS verify server certificate enabled
bootstrap.webservices.ssl.client_ssl_ciphersClient HTTPS ciphers for internal use
bootstrap.webservices.ssl.client_ssl_protocolsClient HTTPS protocols for internal use
bootstrap.webservices.ssl.server_aliasAlias of the certificate entry in euca.p12 to use for SSL for webservices.
bootstrap.webservices.ssl.server_passwordPassword of the private key corresponding to the specified certificate for SSL for web services.
bootstrap.webservices.ssl.server_ssl_ciphersSSL ciphers for web services.
bootstrap.webservices.ssl.server_ssl_protocolsSSL protocols for web services.
bootstrap.webservices.ssl.user_ssl_ciphersSSL ciphers for external use.
bootstrap.webservices.ssl.user_ssl_default_casUse default CAs with SSL for external use.
bootstrap.webservices.ssl.user_ssl_enable_hostname_verificationSSL hostname validation for external use.
bootstrap.webservices.ssl.user_ssl_protocolsSSL protocols for external use.
cloud.db_check_poll_timePoll time (ms) for db connection check
cloud.db_check_thresholdThreshold (number of connections or %) for db connection check
cloud.euca_log_levelLog level for dynamic override.
cloud.identifier_canonicalizerName of the canonicalizer for resource identifiers.
cloud.log_file_disk_check_poll_timePoll time (ms) for log file disk check
cloud.log_file_disk_check_thresholdThreshold (bytes or %) for log file disk check
cloud.memory_check_poll_timePoll time (ms) for memory check
cloud.memory_check_ratioRatio (of post-garbage collected old-gen memory) for memory check
cloud.trigger_faultFault id last used to trigger test
cloud.cluster.disabledintervalThe time period between service state checks for a Cluster Controller which is DISABLED.
cloud.cluster.enabledintervalThe time period between service state checks for a Cluster Controller which is ENABLED.
cloud.cluster.notreadyintervalThe time period between service state checks for a Cluster Controller which is NOTREADY.
cloud.cluster.pendingintervalThe time period between service state checks for a Cluster Controller which is PENDING.
cloud.cluster.requestworkersThe number of concurrent requests which will be sent to a single Cluster Controller.
cloud.cluster.startupsyncretriesThe number of times a request will be retried while bootstrapping a Cluster Controller.
cloud.images.cleanupperiodThe period between runs for clean up of deregistered images.
cloud.images.defaultvisibilityThe default value used to determine whether or not images are marked ‘public’ when first registered.
cloud.images.maximagesizegbThe maximum registerable image size in GB
cloud.images.maxmanifestsizebytesThe maximum allowed image manifest size in bytes
cloud.long_identifier_prefixesList of resource identifier prefixes for long identifiers or * for all
cloud.monitor.default_poll_interval_minsHow often the CLC requests data from the CC. Default value is 5 minutes.
cloud.monitor.history_sizeHow many data value samples are sent from the CC to the CLC. The default value is 5.
cloud.network.address_pending_timeoutMinutes before a pending system public address allocation times out and is released. Default: 35 minutes.
cloud.network.ec2_classic_additional_protocols_allowedComma delimited list of protocol numbers supported in EDGE mode for security group rules beyond the EC2-Classic defaults (TCP,UDP,ICMP). Only valid IANA protocol numbers are accepted. Default: None
cloud.network.max_broadcast_applyMaximum time to apply network information. Default: 120 seconds.
cloud.network.min_broadcast_intervalMinimum interval between broadcasts of network information. Default: 5 seconds.
cloud.network.network_index_pending_timeoutMinutes before a pending index allocation times out and is released. Default: 35 minutes.
cloud.short_identifier_prefixesList of resource identifier prefixes for short identifiers or * for all
cloud.vmstate.buried_timeAmount of time (in minutes) to retain unreported terminated instance data.
cloud.vmstate.ebs_root_device_nameName for root block device mapping
cloud.vmstate.ebs_volume_creation_timeoutAmount of time (in minutes) before a EBS volume backing the instance is created
cloud.vmstate.instance_private_prefixPrivate name prefix for instance DNS
cloud.vmstate.instance_public_prefixPublic name prefix for instance DNS
cloud.vmstate.instance_reachability_timeoutAmount of time (in minutes) before a VM which is not reported by a cluster will fail a reachability test.
cloud.vmstate.instance_subdomainSubdomain to use for instance DNS.
cloud.vmstate.instance_timeoutAmount of time (default unit minutes) before a previously running instance which is not reported will be marked as terminated.
cloud.vmstate.instance_touch_intervalAmount of time (in minutes) between updates for a running instance.
cloud.vmstate.mac_prefixDefault prefix to use for instance / network interface MAC addresses.
cloud.vmstate.max_state_threadsMaximum number of threads the system will use to service blocking state changes.
cloud.vmstate.migration_refresh_timeMaximum amount of time (in seconds) that migration state will take to propagate state changes (e.g., to tags).
cloud.vmstate.pending_timeAmount of time (in minutes) before a pending instance will be terminated.
cloud.vmstate.shut_down_timeAmount of time (in minutes) before a VM which is not reported by a cluster will be marked as terminated.
cloud.vmstate.stopping_timeAmount of time (in minutes) before a stopping VM which is not reported by a cluster will be marked as terminated.
cloud.vmstate.terminated_timeAmount of time (in minutes) that a terminated VM will continue to be reported.
cloud.vmstate.tx_retriesNumber of times to retry transactions in the face of potential concurrent update conflicts.
cloud.vmstate.unknown_instance_handlersComma separated list of handlers to use for unknown instances (‘restore’, ‘restore-failed’, ’terminate’, ’terminate-done’)
cloud.vmstate.user_data_max_size_kbMax length (in KB) that the user data file can be for an instance (after base 64 decoding)
cloud.vmstate.vm_initial_report_timeoutAmount of time (in seconds) since completion of the creating run instance operation that the new instance is treated as unreported if not… reported.
cloud.vmstate.vm_metadata_generated_cacheInstance metadata generated data cache configuration. The cache is used for IAM metadata (../latest/meta-data/iam/) and instance identity (../latest/dynamic/instance-identity/).Default: maximumSize=1000, expireAfterWrite=5m
cloud.vmstate.vm_metadata_instance_cacheInstance metadata cache configuration.
cloud.vmstate.vm_metadata_request_cacheInstance metadata instance resolution cache configuration.
cloud.vmstate.vm_metadata_user_data_cacheInstance metadata user data cache configuration.
cloud.vmstate.vm_state_settle_timeAmount of time (in seconds) to let instance state settle after a transition to either stopping or shutting-down.
cloud.vmstate.volatile_state_interval_secPeriod (in seconds) between state updates for actively changing state.
cloud.vmstate.volatile_state_timeout_secTimeout (in seconds) before a requested instance terminate will be repeated.
cloud.vmtypes.default_type_nameDefault type used when no instance type is specified for run instances.
cloud.vmtypes.format_ephemeral_storageFormat first ephemeral disk by defaut with ext3
cloud.vmtypes.merge_ephemeral_storageMerge non-root ephemeral disks
cloud.volumes.deleted_timeAmount of time (in minutes) that a deleted volume will continue to be reported
cloud.vpc.defaultvpcEnable default VPC.
cloud.vpc.defaultvpccidrCIDR to use when creating default VPCs
cloud.vpc.networkaclspervpcMaximum number of network ACLs for each VPC.
cloud.vpc.reservedcidrsComma separated list of reserved CIDRs
cloud.vpc.routespertableMaximum number of routes for each route table.
cloud.vpc.routetablespervpcMaximum number of route tables for each VPC.
cloud.vpc.rulespernetworkaclMaximum number of rules per direction for each network ACL.
cloud.vpc.rulespersecuritygroupMaximum number of associated security groups for each network interface .
cloud.vpc.securitygroupspernetworkinterfaceMaximum number of associated security groups for each network interface .
cloud.vpc.securitygroupspervpcMaximum number of security groups for each VPC.
cloud.vpc.subnetspervpcMaximum number of subnets for each VPC.
cloudformation.autoscaling_group_deleted_max_delete_retry_secsThe amount of time (in seconds) to wait for an autoscaling group to be deleted after deletion)
cloudformation.autoscaling_group_zero_instances_max_delete_retry_secsThe amount of time (in seconds) to wait for an autoscaling group to have zero instances during delete
cloudformation.cfn_instance_auth_cacheCloudFormation instance credential authentication cache
cloudformation.instance_attach_volume_max_create_retry_secsThe amount of time (in seconds) to wait for an instance to have volumes attached after creation)
cloudformation.instance_running_max_create_retry_secsThe amount of time (in seconds) to wait for an instance to be running after creation)
cloudformation.instance_terminated_max_delete_retry_secsThe amount of time (in seconds) to wait for an instance to be terminated after deletion)
cloudformation.max_attributes_per_mappingThe maximum number of attributes allowed in a mapping in a template
cloudformation.max_mappings_per_templateThe maximum number of mappings allowed in a template
cloudformation.max_outputs_per_templateThe maximum number of outputs allowed in a template
cloudformation.max_parameters_per_templateThe maximum number of outputs allowed in a template
cloudformation.max_resources_per_templateThe maximum number of resources allowed in a template
cloudformation.nat_gateway_available_max_create_retry_secsThe amount of time (in seconds) to wait for a nat gateway to be available after create)
cloudformation.network_interface_attachment_max_create_or_update_retry_secsThe amount of time (in seconds) to wait for a network interface to be attached during create or update)
cloudformation.network_interface_available_max_create_retry_secsThe amount of time (in seconds) to wait for a network interface to be available after create)
cloudformation.network_interface_deleted_max_delete_retry_secsThe amount of time (in seconds) to wait for a network interface to be deleted)
cloudformation.network_interface_detachment_max_delete_or_update_retry_secsThe amount of time (in seconds) to wait for a network interface to detach during delete or update)
cloudformation.pseudo_param_partitionCloudFormation AWS::Partition (default: eucalyptus)
cloudformation.pseudo_param_urlsuffixCloudFormation AWS::URLSuffix (default: dns domain)
cloudformation.regionThe value of AWS::Region and value in CloudFormation ARNs for Region
cloudformation.request_template_body_max_length_bytesThe maximum number of bytes in a request-embedded template
cloudformation.request_template_url_max_content_length_bytesThe maximum number of bytes in a template referenced via a URL
cloudformation.security_group_max_delete_retry_secsThe amount of time (in seconds) to retry security group deletes (may fail if instances from autoscaling group)
cloudformation.subnet_max_delete_retry_secsThe amount of time (in seconds) to retry subnet deletes
cloudformation.swf_activity_worker_configJSON configuration for the cloudformation simple workflow activity worker
cloudformation.swf_domainThe simple workflow service domain for cloudformation
cloudformation.swf_tasklistThe simple workflow service task list for cloudformation
cloudformation.url_domain_whitelistA comma separated white list of domains (other than Eucalyptus S3 URLs) allowed by CloudFormation URL parameters
cloudformation.volume_attachment_max_create_retry_secsThe amount of time (in seconds) to wait for a volume to be attached during create)
cloudformation.volume_available_max_create_retry_secsThe amount of time (in seconds) to wait for a volume to be available after create)
cloudformation.volume_deleted_max_delete_retry_secsThe amount of time (in seconds) to wait for a volume to be deleted)
cloudformation.volume_detachment_max_delete_retry_secsThe amount of time (in seconds) to wait for a volume to detach during delete)
cloudformation.volume_snapshot_complete_max_delete_retry_secsThe amount of time (in seconds) to wait for a snapshot to be complete (if specified as the deletion policy) before a volume is deleted)
cloudformation.wait_condition_bucket_prefixThe prefix of the bucket used for wait condition handles
cloudwatch.disable_cloudwatch_serviceSet this to true to stop cloud watch alarm evaluation and new alarm/metric data entry
dns.dns_listener_address_matchAdditional address patterns to listen on for DNS requests.
dns.enabledEnable pluggable DNS resolvers. This must be ’true’ for any pluggable resolver to work. Also, each resolver may need to be separately enabled.
dns.searchComma separated list of domains to search, OS settings used if none specified (a change requires restart).
dns.serverComma separated list of name servers; OS settings used if none specified (change requires restart)
dns.server_pool_max_threadsServer worker thread pool max.
dns.server_pool_max_threadsServer worker thread pool max.
dns.instancedata.enabledEnable the instance-data resolver. dns.enabled must also be ’true’.
dns.negative_ttlTime-to-live for negative caching on authoritative records. Since version 5.1.
dns.ns.enabledEnable the NS resolver. dns.enabled must also be ’true’.
dns.recursive.enabledEnable the recursive DNS resolver. dns.enabled must also be ’true’.
dns.services.enabledEnable the service topology resolver. dns.enabled must also be ’true’.
dns.split_horizon.enabledEnable the split-horizon DNS resolution for internal instance public DNS name queries. dns.enabled must also be ’true'.
dns.spoof_regions.enabledEnable the spoofing resolver which allows for AWS DNS name emulation for instances.
dns.spoof_regions.region_nameInternal region name. If set, the region name to expect as the second label in the DNS name. For example, to treat your Eucalyptus install like a region named ’eucalyptus’, set this value to eucalyptus. Then, e.g., autoscaling.eucalyptus.amazonaws.com will resolve to the service address when using this DNS server. The specified name creates a pseudo-region with DNS names like ec2.pseudo-region.amazonaws.com will resolve to Eucalyptus endpoints from inside of instances. Here ec2 is any service name supported by Eucalyptus. Those that are not supported will continue to resolve through AWS’s DNS.
dns.spoof_regions.spoof_aws_default_regionsEnable spoofing of the default AWS DNS names, e.g., ec2.amazonaws.com would resolve to the ENABLED Cloud Controller. Here ec2 is any service name supported by Eucalyptus. Those that are not supported will continue to resolve through AWS’s DNS.
dns.spoof_regions.spoof_aws_regionsEnable spoofing for the normal AWS regions, e.g., ec2.us-east-1.amazonaws.com would resolve to the ENABLED Cloud Controller. Here ec2 is any service name supported by Eucalyptus. Those that are not supported will continue to resolve through AWS’s DNS.
dns.tcp.timeout_secondsVariable controlling tcp handler timeout in seconds.
dns.ttlDefault time-to-live for authoritative records. Since version 5.1.
dns.dns_listener_portPort number to listen on for DNS requests
objectstorage.bucket_creation_wait_interval_secondsInterval, in seconds, during which buckets in creating-state are valid. After this interval, the operation is assumed failed.
objectstorage.bucket_naming_restrictionsThe S3 bucket naming restrictions to enforce. Values are ‘dns-compliant’ or ’extended’. Default is ’extended’. dns_compliant is non-US region S3 names, extended is for US-Standard Region naming. See  http://docs.aws.amazon.com/AmazonS3/latest/dev/BucketRestrictions.html.[]()
objectstorage.bucket_reserved_cnamesList of host names that may not be used as bucket cnames
objectstorage.cleanup_task_interval_secondsInterval, in seconds, at which cleanup tasks are initiated for removing old/stale objects.
objectstorage.dogetputoncopyfailShould provider client attempt a GET / PUT when backend does not support Copy operation
objectstorage.failed_put_timeout_hrsNumber of hours to wait for object PUT operations to be allowed to complete before cleanup.
objectstorage.max_buckets_per_accountMaximum number of buckets per account
objectstorage.max_tagsMaximum number of user defined tags for a bucket
objectstorage.max_total_reporting_capacity_gbTotal ObjectStorage storage capacity for Objects solely for reporting usage percentage. Not a size restriction. No enforcement of this value
objectstorage.providerclientObject Storage Provider client to use for backend
objectstorage.queue_sizeChannel buffer queue size for uploads
objectstorage.queue_timeoutChannel buffer queue timeout (in seconds)
objectstorage.s3client.buffer_sizeInternal S3 client buffer size
objectstorage.s3client.connection_timeout_msInternal S3 client connection timeout in ms
objectstorage.s3client.max_connectionsInternal S3 client maximum connections
objectstorage.s3client.max_error_retriesInternal S3 client maximum retries on error
objectstorage.s3client.socket_read_timeout_msInternal S3 client socket read timeout in ms
objectstorage.s3provider.s3accesskeyLocal Store S3 Access Key.
objectstorage.s3provider.s3endpointExternal S3 endpoint.
objectstorage.s3provider.s3secretkeyLocal Store S3 Secret Key.
objectstorage.s3provider.s3usebackenddnsUse DNS virtual-hosted-style bucket names for communication to service backend.
objectstorage.s3provider.s3usehttpsUse HTTPS for communication to service backend.
region.region_enable_sslEnable SSL (HTTPS) for regions.
region.region_nameRegion name.
region.region_ssl_ciphersCiphers to use for region SSL
region.region_ssl_default_casUse default CAs for region SSL connections.
region.region_ssl_protocolsProtocols to use for region SSL
region.region_ssl_verify_hostnamesVerify hostnames for region SSL connections.
services.imaging.import_task_expiration_hoursexpiration hours of import volume/instance tasks
services.imaging.import_task_timeout_minutesexpiration time in minutes of import tasks
services.imaging.worker.availability_zonesavailability zones for imaging worker
services.imaging.worker.configuredPrepare imaging service so a worker can be launched. If something goes south with the service there is a big chance that setting it to false and back to true would solve issues.
services.imaging.worker.expiration_daysthe days after which imaging work VMs expire
services.imaging.worker.healthcheckenabling imaging worker health check
services.imaging.worker.imageEMI containing imaging worker
services.imaging.worker.init_scriptbash script that will be executed before service configuration and start up
services.imaging.worker.instance_typeinstance type for imaging worker
services.imaging.worker.keynamekeyname to use when debugging imaging worker
services.imaging.worker.log_serveraddress/ip of the server that collects logs from imaging wokrers
services.imaging.worker.log_server_portUDP port that log server is listening to
services.imaging.worker.log_server_portUDP port that log server is listening to
services.imaging.worker.ntp_serveraddress of the NTP server used by imaging worker
services.loadbalancing.dns_resolver_enabledEnable the load balancing DNS resolver. dns.enabled must also be ’true’.
services.loadbalancing.dns_subdomainloadbalancer dns subdomain
services.loadbalancing.dns_ttlloadbalancer dns ttl value
services.loadbalancing.max_tagsMaximum number of user defined tags for a load balancer
services.loadbalancing.restricted_portsThe ports restricted for use as a loadbalancer port. Format should be port(, port) or port-port
services.loadbalancing.vm_per_zonenumber of VMs per loadbalancer zone
services.loadbalancing.vpc_cidrsComma separated list of CIDRs for use with ELB VPCs
services.loadbalancing.worker.app_cookie_durationduration of app-controlled cookie to be kept in-memory (hours)
services.loadbalancing.worker.expiration_daysthe days after which the loadbalancer VMs expire
services.loadbalancing.worker.imageEMI containing haproxy and the controller
services.loadbalancing.worker.init_scriptbash script that will be executed before service configuration and start up
services.loadbalancing.worker.instance_typeinstance type for loadbalancer instances
services.loadbalancing.worker.keynamekeyname to use when debugging loadbalancer VMs
services.loadbalancing.worker.ntp_serverthe address of the NTP server used by loadbalancer VMs
services.simpleworkflow.activitytypesperdomainMaximum number of activity types for each domain.
services.simpleworkflow.deprecatedactivitytyperetentiondurationDeprecated activity type retention time.
services.simpleworkflow.deprecateddomainretentiondurationDeprecated domain minimum retention time.
services.simpleworkflow.deprecatedworkflowtyperetentiondurationDeprecated workflow type minimum retention time.
services.simpleworkflow.openactivitytasksperworkflowexecutionMaximum number of open activity tasks for each workflow execution.
services.simpleworkflow.opentimersperworkflowexecutionMaximum number of open timers for each workflow execution.
services.simpleworkflow.openworkflowexecutionsperdomainMaximum number of open workflow executions for each domain.
services.simpleworkflow.systemonlyService available for internal/administrator use only.
services.simpleworkflow.workflowexecutiondurationMaximum workflow execution time.
services.simpleworkflow.workflowexecutionhistorysizeMaximum number of events per workflow execution.
services.simpleworkflow.workflowexecutionretentiondurationMaximum workflow execution history retention time.
services.simpleworkflow.workflowtypesperdomainMaximum number of workflow types for each domain.
stats.config_update_check_interval_secondsInterval, in seconds, at which the sensor configuration is checked for changes
stats.enable_statsEnable Eucalyptus internal monitoring stats
stats.event_emitterInternal stats emitter FQ classname used to send metrics to monitoring system
stats.file_system_emitter.stats_data_permissionsgroup permissions to place on stats data files in string form. eg. rwxr-x–x
stats.file_system_emitter.stats_group_namegroup name that owns stats data files
storage.global_total_snapshot_size_limit_gbMaximum total snapshot capacity (GB)
system.dns.dnsdomainDomain name to use for DNS.
system.dns.nameserverNameserver hostname.
system.dns.nameserveraddressNameserver IP address.
system.dns.nameserveraddressNameserver IP address.
system.dns.registrationidUnique ID of this cloud installation.
system.exec.io_chunk_sizeSize of IO chunks for streaming IO
system.exec.max_restricted_concurrent_opsMaximum number of concurrent processes which match any of the patterns in system.exec.restricted_concurrent_ops.
system.exec.restricted_concurrent_opsComma-separated list of commands which are restricted by system.exec.max_restricted_concurrent_ops.
tagging.max_tags_per_resourceThe maximum number of tags per resource for each account
tokens.disabledactionsActions to disable
tokens.enabledactionsActions to enable (ignored if empty)
tokens.rolearnaliaswhitelistPermitted account aliases for role Amazon Resource Names (ARNs). Value is a list, for example: eucalyptus,aws,dev*,prod* in the case where multiple aliases are permitted. Default: eucalyptus
tokens.webidentityoidcdiscoverycacheCache settings for discovered OpenID Connect metadata: provider configuration and keys. Works with tokens.webidentityoidcdiscoveryrefresh. Default: maximumSize=20, expireAfterWrite=15m
tokens.webidentityoidcdiscoveryrefreshOpenID Connect discovery cache refresh expiry. Controls the time in seconds between checks for updated OIDC metadata. Works with tokens.webidentityoidcdiscoverycache. Default: 60
tokens.webidentitysignaturealgorithmwhitelistList of JSON Web Signature algorithms to allow in web identity tokens. The algorithm whitelist can be used to permit use of these signature algorithms: RS256, RS384, RS512, PS256, PS384, PS512. Default: RS512
tokens.webidentitytokenskewA clock skew value in seconds. The Web identity token expiry / not before validation is allowed within the configured skew. Default: 60
walrusbackend.storagedirPath to buckets storage
ZONE.storage.blockstoragemanagerEBS Block Storage Manager to use for backend
ZONE.storage.cephconfigfileAbsolute path to Ceph configuration (ceph.conf) file. Default value is ‘/etc/ceph/ceph.conf’
ZONE.storage.cephkeyringfileAbsolute path to Ceph keyring (ceph.client.eucalyptus.keyring) file. Default value is ‘/etc/ceph/ceph.client.eucalyptus.keyring’
ZONE.storage.cephsnapshotpoolsCeph storage pool(s) made available to Eucalyptus for EBS snapshots. Use a comma separated list for configuring multiple pools. Default value is ‘rbd’
ZONE.storage.cephuserCeph username employed by Eucalyptus operations. Default value is ’eucalyptus'
ZONE.storage.cephvolumepoolsCeph storage pool(s) made available to Eucalyptus for EBS volumes. Use a comma separated list for configuring multiple pools. Default value is ‘rbd’
ZONE.storage.chapuserUser ID for CHAP authentication
ZONE.storage.dasdeviceDirect attached storage device location
ZONE.storage.maxconcurrentsnapshotsMaximum number of snapshots processed on the block storage backend at a given time
ZONE.storage.maxconcurrentsnapshottransfersMaximum number of snapshots that can be uploaded to or downloaded from objectstorage gateway at a given time
ZONE.storage.maxconcurrentvolumesMaximum number of volumes processed on the block storage backend at a given time
ZONE.storage.maxsnapshotdeltasA non-zero integer value enables upload of incremental snapshots when possible. The configured value indicates the SC to create/upload that many snapshot deltas for a given EBS volume before triggering a full upload of the snapshot contents. Between any two consecutive full snapshot uploads for a given EBS volume, there will be at most maxsnapshotdeltas number of incremental snapshot uploads. A value of 0 indicates that a newly created snapshot will always be uploaded in its entirety (that is, no deltas). Snapshot deltas are only used when your backend is Ceph-RBD. ZONE.storage.shouldtransfersnapshots must be set to true to enable snapshot deltas.Default: 0
ZONE.storage.maxsnapshotpartsqueuesizeMaximum number of snapshot parts per snapshot that can be spooled on the disk
ZONE.storage.maxtotalvolumesizeingbTotal disk space reserved for volumes
ZONE.storage.maxvolumesizeingbMax volume size
ZONE.storage.ncpathsiSCSI Paths for NC. Default value is ’nopath'
ZONE.storage.readbuffersizeinmbBuffer size in MB for reading data from snapshot when uploading snapshot to objectstorage gateway
ZONE.storage.resourceprefixPrefix for resource name on SAN
ZONE.storage.resourcesuffixSuffix for resource name on SAN
ZONE.storage.sanhostHostname for SAN device.
ZONE.storage.sanpasswordPassword for SAN device.
ZONE.storage.sanuserUsername for SAN device.
ZONE.storage.scpathsiSCSI Paths for SC. Default value is ’nopath'
ZONE.storage.shouldtransfersnapshotsEnable snapshot transfer to the OSG. Setting it to false will disable storing snapshots (full or delta) in object storage. While a false setting will reduce object storage requirements, it also prevents the ability to use a snapshot from one availability zone to create a volume in another zone. You can still take/use snapshots even when the setting is false, but you can only use a snapshot to create a volume in the same zone. Must be set to true to use snapshot deltas, which are managed by the ZONE.storage.maxsnapshotdeltas property.Default: true
ZONE.storage.snapexpirationTime interval in minutes after which Storage Controller metadata for snapshots that have been physically removed from the block storage backend will be deleted
ZONE.storage.snapshotpartsizeinmbSnapshot part size in MB for snapshot transfers using multipart upload. Minimum part size is 5MB
ZONE.storage.snapshottransfertimeoutinhoursSnapshot upload wait time in hours after which the upload will be cancelled
ZONE.storage.storeprefixPrefix for ISCSI device
ZONE.storage.tidNext Target ID for ISCSI device
ZONE.storage.timeoutinmillisTimeout value in milli seconds for storage operations
ZONE.storage.volexpirationTime interval in minutes after which Storage Controller metadata for volumes that have been physically removed from the block storage backend will be deleted
ZONE.storage.volumesdirStorage volumes directory.
ZONE.storage.writebuffersizeinmbBuffer size in MB for writing data to snapshot when downloading snapshot from object storage gateway
ZONE.storage.zerofillvolumesShould volumes be zero filled.