package config
- Alphabetic
- Public
- Protected
Type Members
- final case class ActiveContractsServiceConfig(maxWorkingMemoryInBytesForIdPages: Int = LedgerAcsStreamsConfig.default.maxWorkingMemoryInBytesForIdPages, maxIdsPerIdPage: Int = LedgerAcsStreamsConfig.default.maxIdsPerIdPage, maxPagesPerIdPagesBuffer: Int = LedgerAcsStreamsConfig.default.maxPagesPerIdPagesBuffer, maxParallelIdCreateQueries: Int = LedgerAcsStreamsConfig.default.maxParallelIdCreateQueries, maxPayloadsPerPayloadsPage: Int = LedgerAcsStreamsConfig.default.maxPayloadsPerPayloadsPage, maxParallelPayloadCreateQueries: Int = LedgerAcsStreamsConfig.default.maxParallelPayloadCreateQueries, contractProcessingParallelism: Int = LedgerAcsStreamsConfig.default.contractProcessingParallelism) extends Product with Serializable
Ledger api active contracts service specific configurations
Ledger api active contracts service specific configurations
- maxWorkingMemoryInBytesForIdPages
Memory for storing id pages across all id pages buffers. Per single stream.
- maxIdsPerIdPage
Number of event ids to retrieve in a single query (a page of event ids).
- maxPagesPerIdPagesBuffer
Number of id pages to store in a buffer. There is a buffer for each decomposed filtering constraint.
- maxParallelIdCreateQueries
Number of parallel queries that fetch ids of create events. Per single stream.
- maxPayloadsPerPayloadsPage
Number of parallel queries that fetch payloads of create events. Per single stream.
- maxParallelPayloadCreateQueries
Number of event payloads to retrieve in a single query (a page of event payloads). Note _completenessCheck performed in LedgerApiServerConfig above
- sealed trait AuthServiceConfig extends AnyRef
- trait BaseParticipantConfig extends NodeConfig
Base for all participant configs - both local and remote
- final case class CommandServiceConfig(defaultTrackingTimeout: NonNegativeFiniteDuration = NonNegativeFiniteDuration(
CommandConfiguration.Default.defaultTrackingTimeout
), maxCommandsInFlight: Int = CommandConfiguration.Default.maxCommandsInFlight) extends Product with Serializable
Ledger api command service specific configurations
Ledger api command service specific configurations
- defaultTrackingTimeout
default command tracking duration
- maxCommandsInFlight
maximum number of submitted commands waiting to be completed
- final case class CommunityParticipantConfig(init: ParticipantInitConfig = ParticipantInitConfig(), crypto: CommunityCryptoConfig = CommunityCryptoConfig(), ledgerApi: LedgerApiServerConfig = LedgerApiServerConfig(), httpLedgerApiExperimental: Option[HttpApiConfig] = None, adminApi: CommunityAdminServerConfig = CommunityAdminServerConfig(), storage: CommunityStorageConfig = CommunityStorageConfig.Memory(), testingTime: Option[TestingTimeServiceConfig] = None, parameters: ParticipantNodeParameterConfig = ParticipantNodeParameterConfig(), sequencerClient: SequencerClientConfig = SequencerClientConfig(), caching: CachingConfigs = CachingConfigs(), monitoring: NodeMonitoringConfig = NodeMonitoringConfig(), topologyX: TopologyXConfig = TopologyXConfig()) extends LocalParticipantConfig with CommunityLocalNodeConfig with ConfigDefaults[DefaultPorts, CommunityParticipantConfig] with Product with Serializable
Configuration parameters for a single participant
Configuration parameters for a single participant
Please note that any client connecting to the ledger-api of the respective participant must set his GRPC max inbound message size to 2x the value defined here, as we assume that a Canton transaction of N bytes will not be bigger than 2x N on the ledger-api. Though this is just an assumption. Please also note that the participant will refuse to connect to a domain where its max inbound message size is not sufficient to guarantee the processing of all transactions.
- final case class ContractLoaderConfig(maxQueueSize: PositiveInt = ContractLoaderConfig.defaultMaxQueueSize, maxBatchSize: PositiveInt = ContractLoaderConfig.defaultMaxBatchSize, parallelism: PositiveInt = ContractLoaderConfig.defaultMaxParallelism) extends Product with Serializable
Parameters to control batch loading during phase 1 / interpretation
Parameters to control batch loading during phase 1 / interpretation
- maxQueueSize
how many parallel lookups can be queued before we start to backpressure loading
- maxBatchSize
how many contract lookups to batch together
- parallelism
how many parallel contract lookup requests should be sent to the db when prepopulating the cache
- final case class EnterpriseParticipantConfig(init: ParticipantInitConfig = ParticipantInitConfig(), crypto: EnterpriseCryptoConfig = EnterpriseCryptoConfig(), ledgerApi: LedgerApiServerConfig = LedgerApiServerConfig(), httpLedgerApiExperimental: Option[HttpApiConfig] = None, adminApi: EnterpriseAdminServerConfig = EnterpriseAdminServerConfig(), storage: EnterpriseStorageConfig = EnterpriseStorageConfig.Memory(), testingTime: Option[TestingTimeServiceConfig] = None, parameters: ParticipantNodeParameterConfig = ParticipantNodeParameterConfig(), sequencerClient: SequencerClientConfig = SequencerClientConfig(), caching: CachingConfigs = CachingConfigs(), replication: ReplicationConfig = ReplicationConfig(), features: EnterpriseParticipantFeaturesConfig = EnterpriseParticipantFeaturesConfig(), monitoring: NodeMonitoringConfig = NodeMonitoringConfig(), topologyX: TopologyXConfig = TopologyXConfig()) extends LocalParticipantConfig with EnterpriseLocalNodeConfig with ConfigDefaults[DefaultPorts, EnterpriseParticipantConfig] with Product with Serializable
- final case class EnterpriseParticipantFeaturesConfig(profileDir: Option[Path] = None) extends Product with Serializable
Enterprise features configuration
Enterprise features configuration
- profileDir
path to the directory used for Daml profiling
- final case class FlatTransactionStreamsConfig(maxIdsPerIdPage: Int = LedgerTransactionFlatStreamsConfig.default.maxIdsPerIdPage, maxPagesPerIdPagesBuffer: Int = LedgerTransactionFlatStreamsConfig.default.maxPagesPerIdPagesBuffer, maxWorkingMemoryInBytesForIdPages: Int = LedgerTransactionFlatStreamsConfig.default.maxWorkingMemoryInBytesForIdPages, maxPayloadsPerPayloadsPage: Int = LedgerTransactionFlatStreamsConfig.default.maxPayloadsPerPayloadsPage, maxParallelIdCreateQueries: Int = LedgerTransactionFlatStreamsConfig.default.maxParallelIdCreateQueries, maxParallelIdConsumingQueries: Int = LedgerTransactionFlatStreamsConfig.default.maxParallelIdConsumingQueries, maxParallelPayloadCreateQueries: Int = LedgerTransactionFlatStreamsConfig.default.maxParallelPayloadCreateQueries, maxParallelPayloadConsumingQueries: Int = LedgerTransactionFlatStreamsConfig.default.maxParallelPayloadConsumingQueries, maxParallelPayloadQueries: Int = LedgerTransactionFlatStreamsConfig.default.maxParallelPayloadQueries, transactionsProcessingParallelism: Int = LedgerTransactionFlatStreamsConfig.default.transactionsProcessingParallelism) extends Product with Serializable
Ledger API flat transaction streams configuration.
Ledger API flat transaction streams configuration.
- maxIdsPerIdPage
Number of event ids to retrieve in a single query (a page of event ids).
- maxPagesPerIdPagesBuffer
Number of id pages to store in a buffer. There is a buffer for each decomposed filtering constraint.
- maxWorkingMemoryInBytesForIdPages
Memory for storing id pages across all id pages buffers. Per single stream.
- maxPayloadsPerPayloadsPage
Number of event payloads to retrieve in a single query (a page of event payloads).
- maxParallelIdCreateQueries
Number of parallel queries that fetch ids of create events. Per single stream.
- maxParallelIdConsumingQueries
Number of parallel queries that fetch ids of consuming events. Per single stream.
- maxParallelPayloadCreateQueries
Number of parallel queries that fetch payloads of create events. Per single stream.
- maxParallelPayloadConsumingQueries
Number of parallel queries that fetch payloads of consuming events. Per single stream.
- maxParallelPayloadQueries
Upper bound on the number of parallel queries that fetch payloads. Per single stream.
- transactionsProcessingParallelism
Number of transactions to process in parallel. Per single stream.
- final case class IndexerConfig(restartDelay: NonNegativeFiniteDuration = IndexerConfig.DefaultRestartDelay, maxInputBufferSize: NonNegativeInt = NonNegativeInt.tryCreate(DamlIndexerConfig.DefaultMaxInputBufferSize), inputMappingParallelism: NonNegativeInt = NonNegativeInt.tryCreate(DamlIndexerConfig.DefaultInputMappingParallelism), batchingParallelism: NonNegativeInt = NonNegativeInt.tryCreate(DamlIndexerConfig.DefaultBatchingParallelism), ingestionParallelism: NonNegativeInt = NonNegativeInt.tryCreate(DamlIndexerConfig.DefaultIngestionParallelism), submissionBatchSize: Long = DamlIndexerConfig.DefaultSubmissionBatchSize, enableCompression: Boolean = DamlIndexerConfig.DefaultEnableCompression, schemaMigrationAttempts: Int = IndexerStartupMode.DefaultSchemaMigrationAttempts, schemaMigrationAttemptBackoff: NonNegativeFiniteDuration = IndexerConfig.DefaultSchemaMigrationAttemptBackoff, packageMetadataView: PackageMetadataViewConfig = DamlIndexerConfig.DefaultPackageMetadataViewConfig, maxOutputBatchedBufferSize: Int = DamlIndexerConfig.DefaultMaxOutputBatchedBufferSize, maxTailerBatchSize: Int = DamlIndexerConfig.DefaultMaxTailerBatchSize) extends Product with Serializable
Ledger api indexer specific configurations
Ledger api indexer specific configurations
See com.digitalasset.canton.platform.indexer.JdbcIndexer for semantics on these configurations.
- final case class LedgerApiServerConfig(address: String = "127.0.0.1", internalPort: Option[Port] = None, maxEventCacheWeight: Long = 0L, maxContractCacheWeight: Long = 0L, tls: Option[TlsServerConfig] = None, configurationLoadTimeout: NonNegativeFiniteDuration = LedgerApiServerConfig.DefaultConfigurationLoadTimeout, bufferedEventsProcessingParallelism: Int = LedgerApiServerConfig.DefaultEventsProcessingParallelism, bufferedStreamsPageSize: Int = LedgerIndexServiceConfig.DefaultBufferedStreamsPageSize, activeContractsService: ActiveContractsServiceConfig = ActiveContractsServiceConfig(), transactionTreeStreams: TreeTransactionStreamsConfig = TreeTransactionStreamsConfig(), transactionFlatStreams: FlatTransactionStreamsConfig = FlatTransactionStreamsConfig(), globalMaxEventIdQueries: Int = LedgerIndexServiceConfig().globalMaxEventIdQueries, globalMaxEventPayloadQueries: Int = LedgerIndexServiceConfig().globalMaxEventPayloadQueries, commandService: CommandServiceConfig = CommandServiceConfig(), userManagementService: UserManagementServiceConfig = UserManagementServiceConfig(), managementServiceTimeout: NonNegativeFiniteDuration = LedgerApiServerConfig.DefaultManagementServiceTimeout, postgresDataSource: PostgresDataSourceConfigCanton = PostgresDataSourceConfigCanton(), authServices: Seq[AuthServiceConfig] = Seq.empty, keepAliveServer: Option[KeepAliveServerConfig] = Some(KeepAliveServerConfig()), maxContractStateCacheSize: Long = LedgerApiServerConfig.DefaultMaxContractStateCacheSize, maxContractKeyStateCacheSize: Long = LedgerApiServerConfig.DefaultMaxContractKeyStateCacheSize, maxInboundMessageSize: NonNegativeInt = ServerConfig.defaultMaxInboundMessageSize, databaseConnectionTimeout: NonNegativeFiniteDuration = LedgerApiServerConfig.DefaultDatabaseConnectionTimeout, apiStreamShutdownTimeout: NonNegativeFiniteDuration = LedgerApiServerConfig.DefaultApiStreamShutdownTimeout, maxTransactionsInMemoryFanOutBufferSize: Int = LedgerApiServerConfig.DefaultMaxTransactionsInMemoryFanOutBufferSize, additionalMigrationPaths: Seq[String] = Seq.empty, inMemoryStateUpdaterParallelism: Int = LedgerApiServerConfig.DefaultInMemoryStateUpdaterParallelism, inMemoryFanOutThreadPoolSize: Option[Int] = None, rateLimit: Option[RateLimitingConfig] = Some(DefaultRateLimit), preparePackageMetadataTimeOutWarning: NonNegativeFiniteDuration = LedgerApiServerConfig.DefaultPreparePackageMetadataTimeOutWarning, completionsPageSize: Int = LedgerApiServerConfig.DefaultCompletionsPageSize, explicitDisclosureUnsafe: Boolean = false, adminToken: Option[String] = None) extends CommunityServerConfig with Product with Serializable
Canton configuration case class to pass-through configuration options to the ledger api server
Canton configuration case class to pass-through configuration options to the ledger api server
- address
ledger api server host name.
- internalPort
ledger api server port.
- maxEventCacheWeight
ledger api server event cache maximum weight (caffeine cache size)
- maxContractCacheWeight
ledger api server contract cache maximum weight (caffeine cache size)
- tls
tls configuration setting from ledger api server.
- configurationLoadTimeout
ledger api server startup delay if no timemodel has been sent by canton via ReadService
- bufferedEventsProcessingParallelism
parallelism for loading and decoding ledger events for populating Ledger API internal buffers
- activeContractsService
configurations pertaining to the ledger api server's "active contracts service"
- transactionTreeStreams
configurations pertaining to the ledger api server's streams of flat transactions
- transactionFlatStreams
configurations pertaining to the ledger api server's streams of transaction trees
- commandService
configurations pertaining to the ledger api server's "command service"
- managementServiceTimeout
ledger api server management service maximum duration. Duration has to be finite as the ledger api server uses java.time.duration that does not support infinite scala durations.
- postgresDataSource
config for ledger api server when using postgres
- authServices
type of authentication services used by ledger-api server. If empty, we use a wildcard. Otherwise, the first service response that does not say "unauthenticated" will be used.
- keepAliveServer
keep-alive configuration for ledger api requests
- maxContractStateCacheSize
maximum caffeine cache size of mutable state cache of contracts
- maxContractKeyStateCacheSize
maximum caffeine cache size of mutable state cache of contract keys
- maxInboundMessageSize
maximum inbound message size on the ledger api
- databaseConnectionTimeout
database connection timeout
- maxTransactionsInMemoryFanOutBufferSize
maximum number of transactions to hold in the "in-memory fanout" (if enabled)
- additionalMigrationPaths
Optional extra paths for the database migrations
- inMemoryStateUpdaterParallelism
The processing parallelism of the Ledger API server in-memory state updater
- inMemoryFanOutThreadPoolSize
Size of the thread-pool backing the Ledger API in-memory fan-out. If not set, defaults to ((number of thread)/4 + 1)
- rateLimit
limit the ledger api server request rates based on system metrics
- preparePackageMetadataTimeOutWarning
Timeout for package metadata preparation after which a warning will be logged
- completionsPageSize
database / akka page size for batching of ledger api server index ledger completion queries
- explicitDisclosureUnsafe
enable usage of explicitly disclosed contracts in command submission and transaction validation. This feature is deemed unstable and unsafe. Should NOT be enabled in production!
- final case class LedgerApiServerParametersConfig(contractIdSeeding: Seeding = Seeding.Strong, indexer: IndexerConfig = IndexerConfig(), jwtTimestampLeeway: Option[JwtTimestampLeeway] = None, contractLoader: ContractLoaderConfig = ContractLoaderConfig()) extends Product with Serializable
Parameters for the ledger api server
Parameters for the ledger api server
- contractIdSeeding
test-only way to override the contract-id seeding scheme. Must be Strong in production (and Strong is the default). Only configurable to reduce the amount of secure random numbers consumed by tests and to avoid flaky timeouts during continuous integration.
- indexer
parameters how the participant populates the index db used to serve the ledger api
- jwtTimestampLeeway
leeway parameters for JWTs
- trait LocalParticipantConfig extends BaseParticipantConfig with LocalNodeConfig
Base for local participant configurations
- final case class ParticipantInitConfig(identity: Option[Identity] = Some(InitConfigBase.Identity()), ledgerApi: ParticipantLedgerApiInitConfig = ParticipantLedgerApiInitConfig(), parameters: ParticipantParametersInitConfig = ParticipantParametersInitConfig()) extends InitConfigBase with Product with Serializable
Init configuration specific to participant nodes
Init configuration specific to participant nodes
- ledgerApi
ledgerApi related init config
- parameters
participant init config parameters
- final case class ParticipantNodeParameterConfig(adminWorkflow: AdminWorkflowConfig = AdminWorkflowConfig(), partyChangeNotification: PartyNotificationConfig = PartyNotificationConfig.ViaDomain, maxUnzippedDarSize: Int = 1024 * 1024 * 1024, stores: ParticipantStoreConfig = ParticipantStoreConfig(), transferTimeProofFreshnessProportion: NonNegativeInt = NonNegativeInt.tryCreate(3), minimumProtocolVersion: Option[ParticipantProtocolVersion] = Some(
ParticipantProtocolVersion(
ProtocolVersion.v3
)
), initialProtocolVersion: ParticipantProtocolVersion = ParticipantProtocolVersion(
ProtocolVersion.latest
), devVersionSupport: Boolean = false, dontWarnOnDeprecatedPV: Boolean = false, warnIfOverloadedFor: Option[NonNegativeFiniteDuration] = Some(
NonNegativeFiniteDuration.ofSeconds(20)
), ledgerApiServerParameters: LedgerApiServerParametersConfig = LedgerApiServerParametersConfig(), excludeInfrastructureTransactions: Boolean = true, enableEngineStackTraces: Boolean = false, enableContractUpgrading: Boolean = false) extends Product with Serializable
General participant node parameters
General participant node parameters
- adminWorkflow
Configuration options for Canton admin workflows
- partyChangeNotification
Determines how eagerly the participant nodes notify the ledger api of party changes. By default ensure that parties are added via at least one domain before ACKing party creation to ledger api server indexer. This not only avoids flakiness in tests, but reflects that a party is not actually usable in canton until it's available through at least one domain.
- maxUnzippedDarSize
maximum allowed size of unzipped DAR files (in bytes) the participant can accept for uploading. Defaults to 1GB.
- transferTimeProofFreshnessProportion
Proportion of the target domain exclusivity timeout that is used as a freshness bound when requesting a time proof. Setting to 3 means we'll take a 1/3 of the target domain exclusivity timeout and potentially we reuse a recent timeout if one exists within that bound, otherwise a new time proof will be requested. Setting to zero will disable reusing recent time proofs and will instead always fetch a new proof.
- minimumProtocolVersion
The minimum protocol version that this participant will speak when connecting to a domain
- initialProtocolVersion
The initial protocol version used by the participant (default latest), e.g., used to create the initial topology transactions.
- devVersionSupport
If set to true, will allow the participant to connect to a domain with dev protocol version and will turn on unsafe Daml LF versions.
- dontWarnOnDeprecatedPV
If true, then this participant will not emit a warning when connecting to a sequencer using a deprecated protocol version (such as 2.0.0).
- warnIfOverloadedFor
If all incoming commands have been rejected due to PARTICIPANT_BACKPRESSURE during this interval, the participant will log a warning.
- ledgerApiServerParameters
ledger api server parameters The following specialized participant node performance tuning parameters may be grouped once a more final set of configs emerges.
- excludeInfrastructureTransactions
If set, infrastructure transactions (i.e. ping, bong and dar distribution) will be excluded from participant metering.
- enableEngineStackTraces
If true, DAMLe stack traces will be enabled
- enableContractUpgrading
If true contracts may be automatically upgraded or downgraded as needed.
- final case class ParticipantProtocolConfig(minimumProtocolVersion: Option[ProtocolVersion], devVersionSupport: Boolean, dontWarnOnDeprecatedPV: Boolean, initialProtocolVersion: ProtocolVersion) extends ProtocolConfig with Product with Serializable
- final case class ParticipantStoreConfig(maxItemsInSqlClause: PositiveNumeric[Int] = PositiveNumeric.tryCreate(100), maxPruningBatchSize: PositiveNumeric[Int] = PositiveNumeric.tryCreate(1000), ledgerApiPruningBatchSize: PositiveNumeric[Int] = PositiveNumeric.tryCreate(50000), pruningMetricUpdateInterval: Option[PositiveDurationSeconds] = config.PositiveDurationSeconds.ofHours(1L).some, acsPruningInterval: NonNegativeFiniteDuration = NonNegativeFiniteDuration.ofSeconds(60), dbBatchAggregationConfig: BatchAggregatorConfig = BatchAggregatorConfig.Batching()) extends Product with Serializable
Parameters for the participant node's stores
Parameters for the participant node's stores
- maxItemsInSqlClause
maximum number of items to place in sql "in clauses"
- maxPruningBatchSize
maximum number of events to prune from a participant at a time, used to break up canton participant-internal batches
- ledgerApiPruningBatchSize
Number of events to prune from the ledger api server index-database at a time during automatic background pruning. Canton-internal store pruning happens at the smaller batch size of "maxPruningBatchSize" to minimize memory usage whereas ledger-api-server index-db pruning needs sufficiently large batches to amortize the database overhead of "skipping over" active contracts.
- pruningMetricUpdateInterval
How frequently to update the
max-event-age
pruning progress metric in the background. A setting of None disables background metric updating.- acsPruningInterval
How often to prune the ACS journal in the background. A very high interval will let the journal grow larger and eventually slow queries down. A very low interval may cause a high load on the journal table and the DB. The default is 60 seconds. A domain's reconciliation interval also limits the frequency of background pruning. Setting the pruning interval below the reconciliation interval doesn't not increase the frequency further.
- dbBatchAggregationConfig
Batching configuration for Db queries
- sealed trait PartyNotificationConfig extends AnyRef
How eagerly participants make the ledger api aware of added (and eventually changed or removed) parties
- final case class PostgresDataSourceConfigCanton(synchronousCommit: Option[String] = None, tcpKeepalivesIdle: Option[Int] = DefaultPostgresTcpKeepalivesIdle, tcpKeepalivesInterval: Option[Int] = DefaultPostgresTcpKeepalivesInterval, tcpKeepalivesCount: Option[Int] = DefaultPostgresTcpKeepalivesCount) extends Product with Serializable
- final case class RemoteParticipantConfig(adminApi: ClientConfig, ledgerApi: ClientConfig, token: Option[String] = None) extends BaseParticipantConfig with Product with Serializable
Configuration to connect the console to a participant running remotely.
Configuration to connect the console to a participant running remotely.
- adminApi
the configuration to connect the console to the remote admin api
- ledgerApi
the configuration to connect the console to the remote ledger api
- token
optional bearer token to use on the ledger-api if jwt authorization is enabled
- sealed trait TestingTimeServiceConfig extends AnyRef
Optional ledger api time service configuration for demo and testing only
- final case class TreeTransactionStreamsConfig(maxIdsPerIdPage: Int = LedgerTransactionTreeStreamsConfig.default.maxIdsPerIdPage, maxPagesPerIdPagesBuffer: Int = LedgerTransactionTreeStreamsConfig.default.maxPagesPerIdPagesBuffer, maxWorkingMemoryInBytesForIdPages: Int = LedgerTransactionTreeStreamsConfig.default.maxWorkingMemoryInBytesForIdPages, maxPayloadsPerPayloadsPage: Int = LedgerTransactionTreeStreamsConfig.default.maxPayloadsPerPayloadsPage, maxParallelIdCreateQueries: Int = LedgerTransactionTreeStreamsConfig.default.maxParallelIdCreateQueries, maxParallelIdConsumingQueries: Int = LedgerTransactionTreeStreamsConfig.default.maxParallelIdConsumingQueries, maxParallelIdNonConsumingQueries: Int = LedgerTransactionTreeStreamsConfig.default.maxParallelIdNonConsumingQueries, maxParallelPayloadCreateQueries: Int = LedgerTransactionTreeStreamsConfig.default.maxParallelPayloadCreateQueries, maxParallelPayloadConsumingQueries: Int = LedgerTransactionTreeStreamsConfig.default.maxParallelPayloadConsumingQueries, maxParallelPayloadNonConsumingQueries: Int = LedgerTransactionTreeStreamsConfig.default.maxParallelPayloadNonConsumingQueries, maxParallelPayloadQueries: Int = LedgerTransactionTreeStreamsConfig.default.maxParallelPayloadQueries, transactionsProcessingParallelism: Int = LedgerTransactionTreeStreamsConfig.default.transactionsProcessingParallelism) extends Product with Serializable
Ledger API transaction tree streams configuration.
Ledger API transaction tree streams configuration.
- maxIdsPerIdPage
Number of event ids to retrieve in a single query (a page of event ids).
- maxPagesPerIdPagesBuffer
Number of id pages to store in a buffer. There is a buffer for each decomposed filtering constraint.
- maxWorkingMemoryInBytesForIdPages
Memory for storing id pages across all id pages buffers. Per single stream.
- maxPayloadsPerPayloadsPage
Number of event payloads to retrieve in a single query (a page of event payloads).
- maxParallelIdCreateQueries
Number of parallel queries that fetch ids of create events. Per single stream.
- maxParallelIdConsumingQueries
Number of parallel queries that fetch ids of consuming events. Per single stream.
- maxParallelIdNonConsumingQueries
Number of parallel queries that fetch payloads of non-consuming events. Per single stream.
- maxParallelPayloadCreateQueries
Number of parallel queries that fetch payloads of create events. Per single stream.
- maxParallelPayloadConsumingQueries
Number of parallel queries that fetch payloads of consuming events. Per single stream.
- maxParallelPayloadNonConsumingQueries
Number of parallel queries that fetch ids of non-consuming events. Per single stream.
- maxParallelPayloadQueries
Upper bound on the number of parallel queries that fetch payloads. Per single stream.
- transactionsProcessingParallelism
Number of transactions to process in parallel. Per single stream.
- final case class UserManagementServiceConfig(enabled: Boolean = true, maxCacheSize: Int = UserManagementConfig.DefaultMaxCacheSize, cacheExpiryAfterWriteInSeconds: Int = UserManagementConfig.DefaultCacheExpiryAfterWriteInSeconds, maxRightsPerUser: Int = UserManagementConfig.DefaultMaxRightsPerUser, maxUsersPageSize: Int = UserManagementConfig.DefaultMaxUsersPageSize, additionalAdminUserId: Option[String] = None) extends Product with Serializable
Ledger api user management service specific configurations
Ledger api user management service specific configurations
- enabled
whether to enable participant user management
- maxCacheSize
maximum in-memory cache size for user management state
- cacheExpiryAfterWriteInSeconds
determines the maximum delay for propagating user management state changes
- maxRightsPerUser
maximum number of rights per user
- maxUsersPageSize
maximum number of users returned
Value Members
- object ActiveContractsServiceConfig extends Serializable
- object AuthServiceConfig
- object CommandServiceConfig extends Serializable
- object ContractLoaderConfig extends Serializable
- object IndexerConfig extends Serializable
- object LedgerApiServerConfig extends Serializable
- object LocalParticipantConfig
- object ParticipantInitConfig extends Serializable
- object PartyNotificationConfig
- object PostgresDataSourceConfigCanton extends Serializable
- object TestingTimeServiceConfig
- object UserManagementServiceConfig extends Serializable