config

package
v0.2.4 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Sep 10, 2020 License: Apache-2.0 Imports: 11 Imported by: 0

Documentation ¶

Index ¶

Constants ¶

This section is empty.

Variables ¶

This section is empty.

Functions ¶

This section is empty.

Types ¶

type Client ¶

type Client struct {
	// contains filtered or unexported fields
}

Client for config API

func New ¶

func New(transport runtime.ClientTransport, formats strfmt.Registry) *Client

New creates a new config API client.

func (*Client) FindConfigAPIAddress ¶

func (a *Client) FindConfigAPIAddress(params *FindConfigAPIAddressParams) (*FindConfigAPIAddressOK, error)

FindConfigAPIAddress Http Rest API address

func (*Client) FindConfigAPIDocDir ¶

func (a *Client) FindConfigAPIDocDir(params *FindConfigAPIDocDirParams) (*FindConfigAPIDocDirOK, error)

FindConfigAPIDocDir The API definition file directory

func (*Client) FindConfigAPIPort ¶

func (a *Client) FindConfigAPIPort(params *FindConfigAPIPortParams) (*FindConfigAPIPortOK, error)

FindConfigAPIPort Http Rest API port

func (*Client) FindConfigAPIUIDir ¶

func (a *Client) FindConfigAPIUIDir(params *FindConfigAPIUIDirParams) (*FindConfigAPIUIDirOK, error)

FindConfigAPIUIDir The directory location of the API GUI

func (*Client) FindConfigAbortOnLsaBadAlloc ¶

func (a *Client) FindConfigAbortOnLsaBadAlloc(params *FindConfigAbortOnLsaBadAllocParams) (*FindConfigAbortOnLsaBadAllocOK, error)

FindConfigAbortOnLsaBadAlloc Abort when allocation in LSA region fails

func (*Client) FindConfigAuthenticator ¶

func (a *Client) FindConfigAuthenticator(params *FindConfigAuthenticatorParams) (*FindConfigAuthenticatorOK, error)

FindConfigAuthenticator The authentication backend, used to identify users. The available authenticators are:

org.apache.cassandra.auth.AllowAllAuthenticator : Disables authentication; no checks are performed.
org.apache.cassandra.auth.PasswordAuthenticator : Authenticates users with user names and hashed passwords stored in the system_auth.credentials table. If you use the default, 1, and the node with the lone replica goes down, you will not be able to log into the cluster because the system_auth keyspace was not replicated.

Related information: Internal authentication

func (*Client) FindConfigAuthorizer ¶

func (a *Client) FindConfigAuthorizer(params *FindConfigAuthorizerParams) (*FindConfigAuthorizerOK, error)

FindConfigAuthorizer The authorization backend. It implements IAuthenticator, which limits access and provides permissions. The available authorizers are:

AllowAllAuthorizer : Disables authorization; allows any action to any user.
CassandraAuthorizer : Stores permissions in system_auth.permissions table. If you use the default, 1, and the node with the lone replica goes down, you will not be able to log into the cluster because the system_auth keyspace was not replicated.

Related information: Object permissions

func (*Client) FindConfigAutoAdjustFlushQuota ¶

func (a *Client) FindConfigAutoAdjustFlushQuota(params *FindConfigAutoAdjustFlushQuotaParams) (*FindConfigAutoAdjustFlushQuotaOK, error)

FindConfigAutoAdjustFlushQuota true: auto-adjust memtable shares for flush processes

func (*Client) FindConfigAutoBootstrap ¶

func (a *Client) FindConfigAutoBootstrap(params *FindConfigAutoBootstrapParams) (*FindConfigAutoBootstrapOK, error)

FindConfigAutoBootstrap This setting has been removed from default configuration. It makes new (non-seed) nodes automatically migrate the right data to themselves. Do not set this to false unless you really know what you are doing. Related information: Initializing a multiple node cluster (single data center) and Initializing a multiple node cluster (multiple data centers).

func (*Client) FindConfigAutoSnapshot ¶

func (a *Client) FindConfigAutoSnapshot(params *FindConfigAutoSnapshotParams) (*FindConfigAutoSnapshotOK, error)

FindConfigAutoSnapshot Enable or disable whether a snapshot is taken of the data before keyspace truncation or dropping of tables. To prevent data loss, using the default setting is strongly advised. If you set to false, you will lose data on truncation or drop.

func (*Client) FindConfigBackgroundWriterSchedulingQuota ¶

func (a *Client) FindConfigBackgroundWriterSchedulingQuota(params *FindConfigBackgroundWriterSchedulingQuotaParams) (*FindConfigBackgroundWriterSchedulingQuotaOK, error)

FindConfigBackgroundWriterSchedulingQuota max cpu usage ratio (between 0 and 1) for compaction process. Not intended for setting in normal operations. Setting it to 1 or higher will disable it, recommended operational setting is 0.5.

func (*Client) FindConfigBatchSizeFailThresholdInKb ¶

func (a *Client) FindConfigBatchSizeFailThresholdInKb(params *FindConfigBatchSizeFailThresholdInKbParams) (*FindConfigBatchSizeFailThresholdInKbOK, error)

FindConfigBatchSizeFailThresholdInKb Fail any multiple-partition batch exceeding this value. 50kb (10x warn threshold) by default.

func (*Client) FindConfigBatchSizeWarnThresholdInKb ¶

func (a *Client) FindConfigBatchSizeWarnThresholdInKb(params *FindConfigBatchSizeWarnThresholdInKbParams) (*FindConfigBatchSizeWarnThresholdInKbOK, error)

FindConfigBatchSizeWarnThresholdInKb Log WARN on any batch size exceeding this value in kilobytes. Caution should be taken on increasing the size of this threshold as it can lead to node instability.

func (*Client) FindConfigBatchlogReplayThrottleInKb ¶

func (a *Client) FindConfigBatchlogReplayThrottleInKb(params *FindConfigBatchlogReplayThrottleInKbParams) (*FindConfigBatchlogReplayThrottleInKbOK, error)

FindConfigBatchlogReplayThrottleInKb Total maximum throttle. Throttling is reduced proportionally to the number of nodes in the cluster.

func (*Client) FindConfigBroadcastAddress ¶

func (a *Client) FindConfigBroadcastAddress(params *FindConfigBroadcastAddressParams) (*FindConfigBroadcastAddressOK, error)

FindConfigBroadcastAddress The IP address a node tells other nodes in the cluster to contact it by. It allows public and private address to be different. For example, use the broadcast_address parameter in topologies where not all nodes have access to other nodes by their private IP addresses. If your Scylla cluster is deployed across multiple Amazon EC2 regions and you use the EC2MultiRegionSnitch , set the broadcast_address to public IP address of the node and the listen_address to the private IP.

func (*Client) FindConfigBroadcastRPCAddress ¶

func (a *Client) FindConfigBroadcastRPCAddress(params *FindConfigBroadcastRPCAddressParams) (*FindConfigBroadcastRPCAddressOK, error)

FindConfigBroadcastRPCAddress RPC address to broadcast to drivers and other Scylla nodes. This cannot be set to 0.0.0.0. If blank, it is set to the value of the rpc_address or rpc_interface. If rpc_address or rpc_interfaceis set to 0.0.0.0, this property must be set.

func (*Client) FindConfigCPUScheduler ¶

func (a *Client) FindConfigCPUScheduler(params *FindConfigCPUSchedulerParams) (*FindConfigCPUSchedulerOK, error)

FindConfigCPUScheduler Enable cpu scheduling

func (*Client) FindConfigCacheHitRateReadBalancing ¶

func (a *Client) FindConfigCacheHitRateReadBalancing(params *FindConfigCacheHitRateReadBalancingParams) (*FindConfigCacheHitRateReadBalancingOK, error)

FindConfigCacheHitRateReadBalancing This boolean controls whether the replicas for read query will be choosen based on cache hit ratio

func (*Client) FindConfigCasContentionTimeoutInMs ¶

func (a *Client) FindConfigCasContentionTimeoutInMs(params *FindConfigCasContentionTimeoutInMsParams) (*FindConfigCasContentionTimeoutInMsOK, error)

FindConfigCasContentionTimeoutInMs The time that the coordinator continues to retry a CAS (compare and set) operation that contends with other proposals for the same row.

func (*Client) FindConfigClientEncryptionOptions ¶

func (a *Client) FindConfigClientEncryptionOptions(params *FindConfigClientEncryptionOptionsParams) (*FindConfigClientEncryptionOptionsOK, error)

FindConfigClientEncryptionOptions Enable or disable client-to-node encryption. You must also generate keys and provide the appropriate key and certificate. No custom encryption options are currently enabled. The available options are:

enabled : (Default: false ) To enable, set to true.
certificate: (Default: conf/scylla.crt) The location of a PEM-encoded x509 certificate used to identify and encrypt the client/server communication.
keyfile: (Default: conf/scylla.key) PEM Key file associated with certificate.

truststore : (Default: <system truststore> ) Location of the truststore containing the trusted certificate for authenticating remote servers.

The advanced settings are:

priority_string : GnuTLS priority string controlling TLS algorithms used/allowed.
require_client_auth : (Default: false ) Enables or disables certificate authentication.

Related information: Client-to-node encryption

func (*Client) FindConfigClusterName ¶

func (a *Client) FindConfigClusterName(params *FindConfigClusterNameParams) (*FindConfigClusterNameOK, error)

FindConfigClusterName The name of the cluster; used to prevent machines in one logical cluster from joining another. All nodes participating in a cluster must have the same value.

func (*Client) FindConfigColumnIndexSizeInKb ¶

func (a *Client) FindConfigColumnIndexSizeInKb(params *FindConfigColumnIndexSizeInKbParams) (*FindConfigColumnIndexSizeInKbOK, error)

FindConfigColumnIndexSizeInKb Granularity of the index of rows within a partition. For huge rows, decrease this setting to improve seek time. If you use key cache, be careful not to make this setting too large because key cache will be overwhelmed. If you're unsure of the size of the rows, it's best to use the default setting.

func (*Client) FindConfigCommitFailurePolicy ¶

func (a *Client) FindConfigCommitFailurePolicy(params *FindConfigCommitFailurePolicyParams) (*FindConfigCommitFailurePolicyOK, error)

FindConfigCommitFailurePolicy Policy for commit disk failures:

die          Shut down gossip and Thrift and kill the JVM, so the node can be replaced.
stop         Shut down gossip and Thrift, leaving the node effectively dead, but can be inspected using JMX.
stop_commit  Shut down the commit log, letting writes collect but continuing to service reads (as in pre-2.0.5 Cassandra).
ignore       Ignore fatal errors and let the batches fail.

func (*Client) FindConfigCommitlogDirectory ¶

func (a *Client) FindConfigCommitlogDirectory(params *FindConfigCommitlogDirectoryParams) (*FindConfigCommitlogDirectoryOK, error)

FindConfigCommitlogDirectory The directory where the commit log is stored. For optimal write performance, it is recommended the commit log be on a separate disk partition (ideally, a separate physical device) from the data file directories.

func (*Client) FindConfigCommitlogReuseSegments ¶

func (a *Client) FindConfigCommitlogReuseSegments(params *FindConfigCommitlogReuseSegmentsParams) (*FindConfigCommitlogReuseSegmentsOK, error)

FindConfigCommitlogReuseSegments Whether or not to re-use commitlog segments when finished instead of deleting them. Can improve commitlog latency on some file systems.

func (*Client) FindConfigCommitlogSegmentSizeInMb ¶

func (a *Client) FindConfigCommitlogSegmentSizeInMb(params *FindConfigCommitlogSegmentSizeInMbParams) (*FindConfigCommitlogSegmentSizeInMbOK, error)

FindConfigCommitlogSegmentSizeInMb Sets the size of the individual commitlog file segments. A commitlog segment may be archived, deleted, or recycled after all its data has been flushed to SSTables. This amount of data can potentially include commitlog segments from every table in the system. The default size is usually suitable for most commitlog archiving, but if you want a finer granularity, 8 or 16 MB is reasonable. See Commit log archive configuration. Related information: Commit log archive configuration

func (*Client) FindConfigCommitlogSync ¶

func (a *Client) FindConfigCommitlogSync(params *FindConfigCommitlogSyncParams) (*FindConfigCommitlogSyncOK, error)

FindConfigCommitlogSync The method that Scylla uses to acknowledge writes in milliseconds:

periodic : Used with commitlog_sync_period_in_ms (Default: 10000 - 10 seconds ) to control how often the commit log is synchronized to disk. Periodic syncs are acknowledged immediately.
batch : Used with commitlog_sync_batch_window_in_ms (Default: disabled **) to control how long Scylla waits for other writes before performing a sync. When using this method, writes are not acknowledged until fsynced to disk.

Related information: Durability

func (*Client) FindConfigCommitlogSyncBatchWindowInMs ¶

func (a *Client) FindConfigCommitlogSyncBatchWindowInMs(params *FindConfigCommitlogSyncBatchWindowInMsParams) (*FindConfigCommitlogSyncBatchWindowInMsOK, error)

FindConfigCommitlogSyncBatchWindowInMs Controls how long the system waits for other writes before performing a sync in ”batch” mode.

func (*Client) FindConfigCommitlogSyncPeriodInMs ¶

func (a *Client) FindConfigCommitlogSyncPeriodInMs(params *FindConfigCommitlogSyncPeriodInMsParams) (*FindConfigCommitlogSyncPeriodInMsOK, error)

FindConfigCommitlogSyncPeriodInMs Controls how long the system waits for other writes before performing a sync in ”periodic” mode.

func (*Client) FindConfigCommitlogTotalSpaceInMb ¶

func (a *Client) FindConfigCommitlogTotalSpaceInMb(params *FindConfigCommitlogTotalSpaceInMbParams) (*FindConfigCommitlogTotalSpaceInMbOK, error)

FindConfigCommitlogTotalSpaceInMb Total space used for commitlogs. If the used space goes above this value, Scylla rounds up to the next nearest segment multiple and flushes memtables to disk for the oldest commitlog segments, removing those log segments. This reduces the amount of data to replay on startup, and prevents infrequently-updated tables from indefinitely keeping commitlog segments. A small total commitlog space tends to cause more flush activity on less-active tables. Related information: Configuring memtable throughput

func (*Client) FindConfigCommitlogUseoDsync ¶

func (a *Client) FindConfigCommitlogUseoDsync(params *FindConfigCommitlogUseoDsyncParams) (*FindConfigCommitlogUseODsyncOK, error)

FindConfigCommitlogUseoDsync Whether or not to use O_DSYNC mode for commitlog segments IO. Can improve commitlog latency on some file systems.

func (*Client) FindConfigCompactionEnforceMinThreshold ¶

func (a *Client) FindConfigCompactionEnforceMinThreshold(params *FindConfigCompactionEnforceMinThresholdParams) (*FindConfigCompactionEnforceMinThresholdOK, error)

FindConfigCompactionEnforceMinThreshold If set to true, enforce the min_threshold option for compactions strictly. If false (default), Scylla may decide to compact even if below min_threshold

func (*Client) FindConfigCompactionLargeCellWarningThresholdMb ¶

func (a *Client) FindConfigCompactionLargeCellWarningThresholdMb(params *FindConfigCompactionLargeCellWarningThresholdMbParams) (*FindConfigCompactionLargeCellWarningThresholdMbOK, error)

FindConfigCompactionLargeCellWarningThresholdMb Log a warning when writing cells larger than this value

func (*Client) FindConfigCompactionLargePartitionWarningThresholdMb ¶

FindConfigCompactionLargePartitionWarningThresholdMb Log a warning when writing partitions larger than this value

func (*Client) FindConfigCompactionLargeRowWarningThresholdMb ¶

func (a *Client) FindConfigCompactionLargeRowWarningThresholdMb(params *FindConfigCompactionLargeRowWarningThresholdMbParams) (*FindConfigCompactionLargeRowWarningThresholdMbOK, error)

FindConfigCompactionLargeRowWarningThresholdMb Log a warning when writing rows larger than this value

func (*Client) FindConfigCompactionPreheatKeyCache ¶

func (a *Client) FindConfigCompactionPreheatKeyCache(params *FindConfigCompactionPreheatKeyCacheParams) (*FindConfigCompactionPreheatKeyCacheOK, error)

FindConfigCompactionPreheatKeyCache When set to true , cached row keys are tracked during compaction, and re-cached to their new positions in the compacted SSTable. If you have extremely large key caches for tables, set the value to false ; see Global row and key caches properties.

func (*Client) FindConfigCompactionRowsCountWarningThreshold ¶

func (a *Client) FindConfigCompactionRowsCountWarningThreshold(params *FindConfigCompactionRowsCountWarningThresholdParams) (*FindConfigCompactionRowsCountWarningThresholdOK, error)

FindConfigCompactionRowsCountWarningThreshold Log a warning when writing a number of rows larger than this value

func (*Client) FindConfigCompactionStaticShares ¶

func (a *Client) FindConfigCompactionStaticShares(params *FindConfigCompactionStaticSharesParams) (*FindConfigCompactionStaticSharesOK, error)

FindConfigCompactionStaticShares If set to higher than 0, ignore the controller's output and set the compaction shares statically. Do not set this unless you know what you are doing and suspect a problem in the controller. This option will be retired when the controller reaches more maturity

func (*Client) FindConfigCompactionThroughputMbPerSec ¶

func (a *Client) FindConfigCompactionThroughputMbPerSec(params *FindConfigCompactionThroughputMbPerSecParams) (*FindConfigCompactionThroughputMbPerSecOK, error)

FindConfigCompactionThroughputMbPerSec Throttles compaction to the specified total throughput across the entire system. The faster you insert data, the faster you need to compact in order to keep the SSTable count down. The recommended Value is 16 to 32 times the rate of write throughput (in MBs/second). Setting the value to 0 disables compaction throttling. Related information: Configuring compaction

func (*Client) FindConfigConcurrentCompactors ¶

func (a *Client) FindConfigConcurrentCompactors(params *FindConfigConcurrentCompactorsParams) (*FindConfigConcurrentCompactorsOK, error)

FindConfigConcurrentCompactors Sets the number of concurrent compaction processes allowed to run simultaneously on a node, not including validation compactions for anti-entropy repair. Simultaneous compactions help preserve read performance in a mixed read-write workload by mitigating the tendency of small SSTables to accumulate during a single long-running compaction. If compactions run too slowly or too fast, change compaction_throughput_mb_per_sec first.

func (*Client) FindConfigConcurrentCounterWrites ¶

func (a *Client) FindConfigConcurrentCounterWrites(params *FindConfigConcurrentCounterWritesParams) (*FindConfigConcurrentCounterWritesOK, error)

FindConfigConcurrentCounterWrites Counter writes read the current values before incrementing and writing them back. The recommended value is (16 Ă— number_of_drives) .

func (*Client) FindConfigConcurrentReads ¶

func (a *Client) FindConfigConcurrentReads(params *FindConfigConcurrentReadsParams) (*FindConfigConcurrentReadsOK, error)

FindConfigConcurrentReads For workloads with more data than can fit in memory, the bottleneck is reads fetching data from disk. Setting to (16 Ă— number_of_drives) allows operations to queue low enough in the stack so that the OS and drives can reorder them.

func (*Client) FindConfigConcurrentWrites ¶

func (a *Client) FindConfigConcurrentWrites(params *FindConfigConcurrentWritesParams) (*FindConfigConcurrentWritesOK, error)

FindConfigConcurrentWrites Writes in Cassandra are rarely I/O bound, so the ideal number of concurrent writes depends on the number of CPU cores in your system. The recommended value is (8 x number_of_cpu_cores).

func (*Client) FindConfigConsistentRangemovement ¶

func (a *Client) FindConfigConsistentRangemovement(params *FindConfigConsistentRangemovementParams) (*FindConfigConsistentRangemovementOK, error)

FindConfigConsistentRangemovement When set to true, range movements will be consistent. It means: 1) it will refuse to bootstrap a new node if other bootstrapping/leaving/moving nodes detected. 2) data will be streamed to a new node only from the node which is no longer responsible for the token range. Same as -Dcassandra.consistent.rangemovement in cassandra

func (*Client) FindConfigCounterCacheKeysToSave ¶

func (a *Client) FindConfigCounterCacheKeysToSave(params *FindConfigCounterCacheKeysToSaveParams) (*FindConfigCounterCacheKeysToSaveOK, error)

FindConfigCounterCacheKeysToSave Number of keys from the counter cache to save. When disabled all keys are saved.

func (*Client) FindConfigCounterCacheSavePeriod ¶

func (a *Client) FindConfigCounterCacheSavePeriod(params *FindConfigCounterCacheSavePeriodParams) (*FindConfigCounterCacheSavePeriodOK, error)

FindConfigCounterCacheSavePeriod Duration after which Cassandra should save the counter cache (keys only). Caches are saved to saved_caches_directory.

func (*Client) FindConfigCounterCacheSizeInMb ¶

func (a *Client) FindConfigCounterCacheSizeInMb(params *FindConfigCounterCacheSizeInMbParams) (*FindConfigCounterCacheSizeInMbOK, error)

FindConfigCounterCacheSizeInMb When no value is specified a minimum of 2.5% of Heap or 50MB. If you perform counter deletes and rely on low gc_grace_seconds, you should disable the counter cache. To disable, set to 0

func (*Client) FindConfigCounterWriteRequestTimeoutInMs ¶

func (a *Client) FindConfigCounterWriteRequestTimeoutInMs(params *FindConfigCounterWriteRequestTimeoutInMsParams) (*FindConfigCounterWriteRequestTimeoutInMsOK, error)

FindConfigCounterWriteRequestTimeoutInMs The time that the coordinator waits for counter writes to complete.

func (*Client) FindConfigCrossNodeTimeout ¶

func (a *Client) FindConfigCrossNodeTimeout(params *FindConfigCrossNodeTimeoutParams) (*FindConfigCrossNodeTimeoutOK, error)

FindConfigCrossNodeTimeout Enable or disable operation timeout information exchange between nodes (to accurately measure request timeouts). If disabled Cassandra assumes the request was forwarded to the replica instantly by the coordinator. CAUTION: Before enabling this property make sure NTP (network time protocol) is installed and the times are synchronized between the nodes.

func (*Client) FindConfigDataFileDirectories ¶

func (a *Client) FindConfigDataFileDirectories(params *FindConfigDataFileDirectoriesParams) (*FindConfigDataFileDirectoriesOK, error)

FindConfigDataFileDirectories The directory location where table data (SSTables) is stored

func (*Client) FindConfigDefaultLogLevel ¶

func (a *Client) FindConfigDefaultLogLevel(params *FindConfigDefaultLogLevelParams) (*FindConfigDefaultLogLevelOK, error)

FindConfigDefaultLogLevel find config default log level API

func (*Client) FindConfigDefragmentMemoryOnIdle ¶

func (a *Client) FindConfigDefragmentMemoryOnIdle(params *FindConfigDefragmentMemoryOnIdleParams) (*FindConfigDefragmentMemoryOnIdleOK, error)

FindConfigDefragmentMemoryOnIdle When set to true, will defragment memory when the cpu is idle. This reduces the amount of work Scylla performs when processing client requests.

func (*Client) FindConfigDeveloperMode ¶

func (a *Client) FindConfigDeveloperMode(params *FindConfigDeveloperModeParams) (*FindConfigDeveloperModeOK, error)

FindConfigDeveloperMode Relax environment checks. Setting to true can reduce performance and reliability significantly.

func (*Client) FindConfigDiskFailurePolicy ¶

func (a *Client) FindConfigDiskFailurePolicy(params *FindConfigDiskFailurePolicyParams) (*FindConfigDiskFailurePolicyOK, error)

FindConfigDiskFailurePolicy Sets how Scylla responds to disk failure. Recommend settings are stop or best_effort.

die              Shut down gossip and Thrift and kill the JVM for any file system errors or single SSTable errors, so the node can be replaced.
stop_paranoid    Shut down gossip and Thrift even for single SSTable errors.
stop             Shut down gossip and Thrift, leaving the node effectively dead, but available for inspection using JMX.
best_effort      Stop using the failed disk and respond to requests based on the remaining available SSTables. This means you will see obsolete data at consistency level of ONE.
ignore           Ignores fatal errors and lets the requests fail; all file system errors are logged but otherwise ignored. Scylla acts as in versions prior to Cassandra 1.2.

Related information: Handling Disk Failures In Cassandra 1.2 blog and Recovering from a single disk failure using JBOD.

func (*Client) FindConfigDynamicSnitchBadnessThreshold ¶

func (a *Client) FindConfigDynamicSnitchBadnessThreshold(params *FindConfigDynamicSnitchBadnessThresholdParams) (*FindConfigDynamicSnitchBadnessThresholdOK, error)

FindConfigDynamicSnitchBadnessThreshold Sets the performance threshold for dynamically routing requests away from a poorly performing node. A value of 0.2 means Cassandra continues to prefer the static snitch values until the node response time is 20% worse than the best performing node. Until the threshold is reached, incoming client requests are statically routed to the closest replica (as determined by the snitch). Having requests consistently routed to a given replica can help keep a working set of data hot when read repair is less than 1.

func (*Client) FindConfigDynamicSnitchResetIntervalInMs ¶

func (a *Client) FindConfigDynamicSnitchResetIntervalInMs(params *FindConfigDynamicSnitchResetIntervalInMsParams) (*FindConfigDynamicSnitchResetIntervalInMsOK, error)

FindConfigDynamicSnitchResetIntervalInMs Time interval in milliseconds to reset all node scores, which allows a bad node to recover.

func (*Client) FindConfigDynamicSnitchUpdateIntervalInMs ¶

func (a *Client) FindConfigDynamicSnitchUpdateIntervalInMs(params *FindConfigDynamicSnitchUpdateIntervalInMsParams) (*FindConfigDynamicSnitchUpdateIntervalInMsOK, error)

FindConfigDynamicSnitchUpdateIntervalInMs The time interval for how often the snitch calculates node scores. Because score calculation is CPU intensive, be careful when reducing this interval.

func (*Client) FindConfigEnableCache ¶

func (a *Client) FindConfigEnableCache(params *FindConfigEnableCacheParams) (*FindConfigEnableCacheOK, error)

FindConfigEnableCache Enable cache

func (*Client) FindConfigEnableCommitlog ¶

func (a *Client) FindConfigEnableCommitlog(params *FindConfigEnableCommitlogParams) (*FindConfigEnableCommitlogOK, error)

FindConfigEnableCommitlog Enable commitlog

func (*Client) FindConfigEnableDangerousDirectImportOfCassandraCounters ¶

FindConfigEnableDangerousDirectImportOfCassandraCounters Only turn this option on if you want to import tables from Cassandra containing counters, and you are SURE that no counters in that table were created in a version earlier than Cassandra 2.1. It is not enough to have ever since upgraded to newer versions of Cassandra. If you EVER used a version earlier than 2.1 in the cluster where these SSTables come from, DO NOT TURN ON THIS OPTION! You will corrupt your data. You have been warned.

func (*Client) FindConfigEnableDeprecatedPartitioners ¶

func (a *Client) FindConfigEnableDeprecatedPartitioners(params *FindConfigEnableDeprecatedPartitionersParams) (*FindConfigEnableDeprecatedPartitionersOK, error)

FindConfigEnableDeprecatedPartitioners Enable the byteordered and murmurs partitioners. These partitioners are deprecated and will be removed in a future version.

func (*Client) FindConfigEnableInMemoryDataStore ¶

func (a *Client) FindConfigEnableInMemoryDataStore(params *FindConfigEnableInMemoryDataStoreParams) (*FindConfigEnableInMemoryDataStoreOK, error)

FindConfigEnableInMemoryDataStore Enable in memory mode (system tables are always persisted)

func (*Client) FindConfigEnableKeyspaceColumnFamilyMetrics ¶

func (a *Client) FindConfigEnableKeyspaceColumnFamilyMetrics(params *FindConfigEnableKeyspaceColumnFamilyMetricsParams) (*FindConfigEnableKeyspaceColumnFamilyMetricsOK, error)

FindConfigEnableKeyspaceColumnFamilyMetrics Enable per keyspace and per column family metrics reporting

func (*Client) FindConfigEnableShardAwareDrivers ¶

func (a *Client) FindConfigEnableShardAwareDrivers(params *FindConfigEnableShardAwareDriversParams) (*FindConfigEnableShardAwareDriversOK, error)

FindConfigEnableShardAwareDrivers Enable native transport drivers to use connection-per-shard for better performance

func (*Client) FindConfigEnableSstableDataIntegrityCheck ¶

func (a *Client) FindConfigEnableSstableDataIntegrityCheck(params *FindConfigEnableSstableDataIntegrityCheckParams) (*FindConfigEnableSstableDataIntegrityCheckOK, error)

FindConfigEnableSstableDataIntegrityCheck Enable interposer which checks for integrity of every sstable write. Performance is affected to some extent as a result. Useful to help debugging problems that may arise at another layers.

func (*Client) FindConfigEnableSstablesMcFormat ¶

func (a *Client) FindConfigEnableSstablesMcFormat(params *FindConfigEnableSstablesMcFormatParams) (*FindConfigEnableSstablesMcFormatOK, error)

FindConfigEnableSstablesMcFormat Enable SSTables 'mc' format to be used as the default file format

func (*Client) FindConfigEndpointSnitch ¶

func (a *Client) FindConfigEndpointSnitch(params *FindConfigEndpointSnitchParams) (*FindConfigEndpointSnitchOK, error)

FindConfigEndpointSnitch Set to a class that implements the IEndpointSnitch. Scylla uses snitches for locating nodes and routing requests.

SimpleSnitch: Use for single-data center deployments or single-zone in public clouds. Does not recognize data center or rack information. It treats strategy order as proximity, which can improve cache locality when disabling read repair.

GossipingPropertyFileSnitch: Recommended for production. The rack and data center for the local node are defined in the cassandra-rackdc.properties file and propagated to other nodes via gossip. To allow migration from the PropertyFileSnitch, it uses the cassandra-topology.properties file if it is present.

Ec2Snitch: For EC2 deployments in a single region. Loads region and availability zone information from the EC2 API. The region is treated as the data center and the availability zone as the rack. Uses only private IPs. Subsequently it does not work across multiple regions.

Ec2MultiRegionSnitch: Uses public IPs as the broadcast_address to allow cross-region connectivity. This means you must also set seed addresses to the public IP and open the storage_port or ssl_storage_port on the public IP firewall. For intra-region traffic, Scylla switches to the private IP after establishing a connection.

GoogleCloudSnitch: For deployments on Google Cloud Platform across one or more regions. The region is treated as a datacenter and the availability zone is treated as a rack within the datacenter. The communication should occur over private IPs within the same logical network.

RackInferringSnitch: Proximity is determined by rack and data center, which are assumed to correspond to the 3rd and 2nd octet of each node's IP address, respectively. This snitch is best used as an example for writing a custom snitch class (unless this happens to match your deployment conventions).

Related information: Snitches

func (*Client) FindConfigExperimental ¶

func (a *Client) FindConfigExperimental(params *FindConfigExperimentalParams) (*FindConfigExperimentalOK, error)

FindConfigExperimental Set to true to unlock experimental features.

func (*Client) FindConfigFdInitialValueMs ¶

func (a *Client) FindConfigFdInitialValueMs(params *FindConfigFdInitialValueMsParams) (*FindConfigFdInitialValueMsOK, error)

FindConfigFdInitialValueMs The initial failure_detector interval time in milliseconds.

func (*Client) FindConfigFdMaxIntervalMs ¶

func (a *Client) FindConfigFdMaxIntervalMs(params *FindConfigFdMaxIntervalMsParams) (*FindConfigFdMaxIntervalMsOK, error)

FindConfigFdMaxIntervalMs The maximum failure_detector interval time in milliseconds. Interval larger than the maximum will be ignored. Larger cluster may need to increase the default.

func (*Client) FindConfigFileCacheSizeInMb ¶

func (a *Client) FindConfigFileCacheSizeInMb(params *FindConfigFileCacheSizeInMbParams) (*FindConfigFileCacheSizeInMbOK, error)

FindConfigFileCacheSizeInMb Total memory to use for SSTable-reading buffers.

func (*Client) FindConfigHintedHandoffEnabled ¶

func (a *Client) FindConfigHintedHandoffEnabled(params *FindConfigHintedHandoffEnabledParams) (*FindConfigHintedHandoffEnabledOK, error)

FindConfigHintedHandoffEnabled Enable or disable hinted handoff. To enable per data center, add data center list. For example: hinted_handoff_enabled: DC1,DC2. A hint indicates that the write needs to be replayed to an unavailable node. Related information: About hinted handoff writes

func (*Client) FindConfigHintedHandoffThrottleInKb ¶

func (a *Client) FindConfigHintedHandoffThrottleInKb(params *FindConfigHintedHandoffThrottleInKbParams) (*FindConfigHintedHandoffThrottleInKbOK, error)

FindConfigHintedHandoffThrottleInKb Maximum throttle per delivery thread in kilobytes per second. This rate reduces proportionally to the number of nodes in the cluster. For example, if there are two nodes in the cluster, each delivery thread will use the maximum rate. If there are three, each node will throttle to half of the maximum, since the two nodes are expected to deliver hints simultaneously.

func (*Client) FindConfigHintsDirectory ¶

func (a *Client) FindConfigHintsDirectory(params *FindConfigHintsDirectoryParams) (*FindConfigHintsDirectoryOK, error)

FindConfigHintsDirectory The directory where hints files are stored if hinted handoff is enabled.

func (*Client) FindConfigInMemoryCompactionLimitInMb ¶

func (a *Client) FindConfigInMemoryCompactionLimitInMb(params *FindConfigInMemoryCompactionLimitInMbParams) (*FindConfigInMemoryCompactionLimitInMbOK, error)

FindConfigInMemoryCompactionLimitInMb Size limit for rows being compacted in memory. Larger rows spill to disk and use a slower two-pass compaction process. When this occurs, a message is logged specifying the row key. The recommended value is 5 to 10 percent of the available Java heap size.

func (*Client) FindConfigIncrementalBackups ¶

func (a *Client) FindConfigIncrementalBackups(params *FindConfigIncrementalBackupsParams) (*FindConfigIncrementalBackupsOK, error)

FindConfigIncrementalBackups Backs up data updated since the last snapshot was taken. When enabled, Scylla creates a hard link to each SSTable flushed or streamed locally in a backups/ subdirectory of the keyspace data. Removing these links is the operator's responsibility. Related information: Enabling incremental backups

func (*Client) FindConfigIndexSummaryCapacityInMb ¶

func (a *Client) FindConfigIndexSummaryCapacityInMb(params *FindConfigIndexSummaryCapacityInMbParams) (*FindConfigIndexSummaryCapacityInMbOK, error)

FindConfigIndexSummaryCapacityInMb Fixed memory pool size in MB for SSTable index summaries. If the memory usage of all index summaries exceeds this limit, any SSTables with low read rates shrink their index summaries to meet this limit. This is a best-effort process. In extreme conditions, Cassandra may need to use more than this amount of memory.

func (*Client) FindConfigIndexSummaryResizeIntervalInMinutes ¶

func (a *Client) FindConfigIndexSummaryResizeIntervalInMinutes(params *FindConfigIndexSummaryResizeIntervalInMinutesParams) (*FindConfigIndexSummaryResizeIntervalInMinutesOK, error)

FindConfigIndexSummaryResizeIntervalInMinutes How frequently index summaries should be re-sampled. This is done periodically to redistribute memory from the fixed-size pool to SSTables proportional their recent read rates. To disable, set to -1. This leaves existing index summaries at their current sampling level.

func (*Client) FindConfigInitialToken ¶

func (a *Client) FindConfigInitialToken(params *FindConfigInitialTokenParams) (*FindConfigInitialTokenOK, error)

FindConfigInitialToken Used in the single-node-per-token architecture, where a node owns exactly one contiguous range in the ring space. Setting this property overrides num_tokens. If you not using vnodes or have num_tokens set it to 1 or unspecified (#num_tokens), you should always specify this parameter when setting up a production cluster for the first time and when adding capacity. For more information, see this parameter in the Cassandra 1.1 Node and Cluster Configuration documentation. This parameter can be used with num_tokens (vnodes ) in special cases such as Restoring from a snapshot.

func (*Client) FindConfigInterDcStreamThroughputOutboundMegabitsPerSec ¶

FindConfigInterDcStreamThroughputOutboundMegabitsPerSec Throttles all streaming file transfer between the data centers. This setting allows throttles streaming throughput betweens data centers in addition to throttling all network stream traffic as configured with stream_throughput_outbound_megabits_per_sec.

func (*Client) FindConfigInterDcTCPNodelay ¶

func (a *Client) FindConfigInterDcTCPNodelay(params *FindConfigInterDcTCPNodelayParams) (*FindConfigInterDcTCPNodelayOK, error)

FindConfigInterDcTCPNodelay Enable or disable tcp_nodelay for inter-data center communication. When disabled larger, but fewer, network packets are sent. This reduces overhead from the TCP protocol itself. However, if cross data-center responses are blocked, it will increase latency.

func (*Client) FindConfigInternodeAuthenticator ¶

func (a *Client) FindConfigInternodeAuthenticator(params *FindConfigInternodeAuthenticatorParams) (*FindConfigInternodeAuthenticatorOK, error)

FindConfigInternodeAuthenticator Internode authentication backend. It implements org.apache.cassandra.auth.AllowAllInternodeAuthenticator to allows or disallow connections from peer nodes.

func (*Client) FindConfigInternodeCompression ¶

func (a *Client) FindConfigInternodeCompression(params *FindConfigInternodeCompressionParams) (*FindConfigInternodeCompressionOK, error)

FindConfigInternodeCompression Controls whether traffic between nodes is compressed. The valid values are:

all: All traffic is compressed.
dc : Traffic between data centers is compressed.
none : No compression.

func (*Client) FindConfigInternodeRecvBuffSizeInBytes ¶

func (a *Client) FindConfigInternodeRecvBuffSizeInBytes(params *FindConfigInternodeRecvBuffSizeInBytesParams) (*FindConfigInternodeRecvBuffSizeInBytesOK, error)

FindConfigInternodeRecvBuffSizeInBytes Sets the receiving socket buffer size in bytes for inter-node calls.

func (*Client) FindConfigInternodeSendBuffSizeInBytes ¶

func (a *Client) FindConfigInternodeSendBuffSizeInBytes(params *FindConfigInternodeSendBuffSizeInBytesParams) (*FindConfigInternodeSendBuffSizeInBytesOK, error)

FindConfigInternodeSendBuffSizeInBytes Sets the sending socket buffer size in bytes for inter-node calls. When setting this parameter and internode_recv_buff_size_in_bytes, the buffer size is limited by net.core.wmem_max. When unset, buffer size is defined by net.ipv4.tcp_wmem. See man tcp and:

/proc/sys/net/core/wmem_max
/proc/sys/net/core/rmem_max
/proc/sys/net/ipv4/tcp_wmem
/proc/sys/net/ipv4/tcp_wmem

func (*Client) FindConfigJoinRing ¶

func (a *Client) FindConfigJoinRing(params *FindConfigJoinRingParams) (*FindConfigJoinRingOK, error)

FindConfigJoinRing When set to true, a node will join the token ring. When set to false, a node will not join the token ring. User can use nodetool join to initiate ring joinging later. Same as -Dcassandra.join_ring in cassandra.

func (*Client) FindConfigKeyCacheKeysToSave ¶

func (a *Client) FindConfigKeyCacheKeysToSave(params *FindConfigKeyCacheKeysToSaveParams) (*FindConfigKeyCacheKeysToSaveOK, error)

FindConfigKeyCacheKeysToSave Number of keys from the key cache to save. (0: all)

func (*Client) FindConfigKeyCacheSavePeriod ¶

func (a *Client) FindConfigKeyCacheSavePeriod(params *FindConfigKeyCacheSavePeriodParams) (*FindConfigKeyCacheSavePeriodOK, error)

FindConfigKeyCacheSavePeriod Duration in seconds that keys are saved in cache. Caches are saved to saved_caches_directory. Saved caches greatly improve cold-start speeds and has relatively little effect on I/O.

func (*Client) FindConfigKeyCacheSizeInMb ¶

func (a *Client) FindConfigKeyCacheSizeInMb(params *FindConfigKeyCacheSizeInMbParams) (*FindConfigKeyCacheSizeInMbOK, error)

FindConfigKeyCacheSizeInMb A global cache setting for tables. It is the maximum size of the key cache in memory. To disable set to 0. Related information: nodetool setcachecapacity.

func (*Client) FindConfigLargeMemoryAllocationWarningThreshold ¶

func (a *Client) FindConfigLargeMemoryAllocationWarningThreshold(params *FindConfigLargeMemoryAllocationWarningThresholdParams) (*FindConfigLargeMemoryAllocationWarningThresholdOK, error)

FindConfigLargeMemoryAllocationWarningThreshold Warn about memory allocations above this size; set to zero to disable

func (*Client) FindConfigListenAddress ¶

func (a *Client) FindConfigListenAddress(params *FindConfigListenAddressParams) (*FindConfigListenAddressOK, error)

FindConfigListenAddress The IP address or hostname that Scylla binds to for connecting to other Scylla nodes. Set this parameter or listen_interface, not both. You must change the default setting for multiple nodes to communicate:

Generally set to empty. If the node is properly configured (host name, name resolution, and so on), Scylla uses InetAddress.getLocalHost() to get the local address from the system. For a single node cluster, you can use the default setting (localhost). If Scylla can't find the correct address, you must specify the IP address or host name. Never specify 0.0.0.0; it is always wrong.

func (*Client) FindConfigListenInterface ¶

func (a *Client) FindConfigListenInterface(params *FindConfigListenInterfaceParams) (*FindConfigListenInterfaceOK, error)

FindConfigListenInterface The interface that Scylla binds to for connecting to other Scylla nodes. Interfaces must correspond to a single address, IP aliasing is not supported. See listen_address.

func (*Client) FindConfigListenOnBroadcastAddress ¶

func (a *Client) FindConfigListenOnBroadcastAddress(params *FindConfigListenOnBroadcastAddressParams) (*FindConfigListenOnBroadcastAddressOK, error)

FindConfigListenOnBroadcastAddress When using multiple physical network interfaces, set this to true to listen on broadcast_address in addition to the listen_address, allowing nodes to communicate in both interfaces. Ignore this property if the network configuration automatically routes between the public and private networks such as EC2.

func (*Client) FindConfigLoadBalance ¶

func (a *Client) FindConfigLoadBalance(params *FindConfigLoadBalanceParams) (*FindConfigLoadBalanceOK, error)

FindConfigLoadBalance CQL request load balancing: 'none' or round-robin'

func (*Client) FindConfigLoadRingState ¶

func (a *Client) FindConfigLoadRingState(params *FindConfigLoadRingStateParams) (*FindConfigLoadRingStateOK, error)

FindConfigLoadRingState When set to true, load tokens and host_ids previously saved. Same as -Dcassandra.load_ring_state in cassandra.

func (*Client) FindConfigLogToStdout ¶

func (a *Client) FindConfigLogToStdout(params *FindConfigLogToStdoutParams) (*FindConfigLogToStdoutOK, error)

FindConfigLogToStdout find config log to stdout API

func (*Client) FindConfigLogToSyslog ¶

func (a *Client) FindConfigLogToSyslog(params *FindConfigLogToSyslogParams) (*FindConfigLogToSyslogOK, error)

FindConfigLogToSyslog find config log to syslog API

func (*Client) FindConfigLoggerLogLevel ¶

func (a *Client) FindConfigLoggerLogLevel(params *FindConfigLoggerLogLevelParams) (*FindConfigLoggerLogLevelOK, error)

FindConfigLoggerLogLevel find config logger log level API

func (*Client) FindConfigLsaReclamationStep ¶

func (a *Client) FindConfigLsaReclamationStep(params *FindConfigLsaReclamationStepParams) (*FindConfigLsaReclamationStepOK, error)

FindConfigLsaReclamationStep Minimum number of segments to reclaim in a single step

func (*Client) FindConfigMaxHintWindowInMs ¶

func (a *Client) FindConfigMaxHintWindowInMs(params *FindConfigMaxHintWindowInMsParams) (*FindConfigMaxHintWindowInMsOK, error)

FindConfigMaxHintWindowInMs Maximum amount of time that hints are generates hints for an unresponsive node. After this interval, new hints are no longer generated until the node is back up and responsive. If the node goes down again, a new interval begins. This setting can prevent a sudden demand for resources when a node is brought back online and the rest of the cluster attempts to replay a large volume of hinted writes. Related information: Failure detection and recovery

func (*Client) FindConfigMaxHintsDeliveryThreads ¶

func (a *Client) FindConfigMaxHintsDeliveryThreads(params *FindConfigMaxHintsDeliveryThreadsParams) (*FindConfigMaxHintsDeliveryThreadsOK, error)

FindConfigMaxHintsDeliveryThreads Number of threads with which to deliver hints. In multiple data-center deployments, consider increasing this number because cross data-center handoff is generally slower.

func (*Client) FindConfigMemoryAllocator ¶

func (a *Client) FindConfigMemoryAllocator(params *FindConfigMemoryAllocatorParams) (*FindConfigMemoryAllocatorOK, error)

FindConfigMemoryAllocator The off-heap memory allocator. In addition to caches, this property affects storage engine meta data. Supported values:

NativeAllocator
JEMallocAllocator

Experiments show that jemalloc saves some memory compared to the native allocator because it is more fragmentation resistant. To use, install jemalloc as a library and modify cassandra-env.sh (instructions in file).

func (*Client) FindConfigMemtableAllocationType ¶

func (a *Client) FindConfigMemtableAllocationType(params *FindConfigMemtableAllocationTypeParams) (*FindConfigMemtableAllocationTypeOK, error)

FindConfigMemtableAllocationType Specify the way Cassandra allocates and manages memtable memory. See Off-heap memtables in Cassandra 2.1. Options are:

heap_buffers     On heap NIO (non-blocking I/O) buffers.
offheap_buffers  Off heap (direct) NIO buffers.
offheap_objects  Native memory, eliminating NIO buffer heap overhead.

func (*Client) FindConfigMemtableCleanupThreshold ¶

func (a *Client) FindConfigMemtableCleanupThreshold(params *FindConfigMemtableCleanupThresholdParams) (*FindConfigMemtableCleanupThresholdOK, error)

FindConfigMemtableCleanupThreshold Ratio of occupied non-flushing memtable size to total permitted size for triggering a flush of the largest memtable. Larger values mean larger flushes and less compaction, but also less concurrent flush activity, which can make it difficult to keep your disks saturated under heavy write load.

func (*Client) FindConfigMemtableFlushQueueSize ¶

func (a *Client) FindConfigMemtableFlushQueueSize(params *FindConfigMemtableFlushQueueSizeParams) (*FindConfigMemtableFlushQueueSizeOK, error)

FindConfigMemtableFlushQueueSize The number of full memtables to allow pending flush (memtables waiting for a write thread). At a minimum, set to the maximum number of indexes created on a single table. Related information: Flushing data from the memtable

func (*Client) FindConfigMemtableFlushStaticShares ¶

func (a *Client) FindConfigMemtableFlushStaticShares(params *FindConfigMemtableFlushStaticSharesParams) (*FindConfigMemtableFlushStaticSharesOK, error)

FindConfigMemtableFlushStaticShares If set to higher than 0, ignore the controller's output and set the memtable shares statically. Do not set this unless you know what you are doing and suspect a problem in the controller. This option will be retired when the controller reaches more maturity

func (*Client) FindConfigMemtableFlushWriters ¶

func (a *Client) FindConfigMemtableFlushWriters(params *FindConfigMemtableFlushWritersParams) (*FindConfigMemtableFlushWritersOK, error)

FindConfigMemtableFlushWriters Sets the number of memtable flush writer threads. These threads are blocked by disk I/O, and each one holds a memtable in memory while blocked. If you have a large Java heap size and many data directories, you can increase the value for better flush performance.

func (*Client) FindConfigMemtableHeapSpaceInMb ¶

func (a *Client) FindConfigMemtableHeapSpaceInMb(params *FindConfigMemtableHeapSpaceInMbParams) (*FindConfigMemtableHeapSpaceInMbOK, error)

FindConfigMemtableHeapSpaceInMb Total permitted memory to use for memtables. Triggers a flush based on memtable_cleanup_threshold. Cassandra stops accepting writes when the limit is exceeded until a flush completes. If unset, sets to default.

func (*Client) FindConfigMemtableOffheapSpaceInMb ¶

func (a *Client) FindConfigMemtableOffheapSpaceInMb(params *FindConfigMemtableOffheapSpaceInMbParams) (*FindConfigMemtableOffheapSpaceInMbOK, error)

FindConfigMemtableOffheapSpaceInMb See memtable_heap_space_in_mb

func (*Client) FindConfigMemtableTotalSpaceInMb ¶

func (a *Client) FindConfigMemtableTotalSpaceInMb(params *FindConfigMemtableTotalSpaceInMbParams) (*FindConfigMemtableTotalSpaceInMbOK, error)

FindConfigMemtableTotalSpaceInMb Specifies the total memory used for all memtables on a node. This replaces the per-table storage settings memtable_operations_in_millions and memtable_throughput_in_mb.

func (*Client) FindConfigMurmur3PartitionerIgnoreMsbBits ¶

func (a *Client) FindConfigMurmur3PartitionerIgnoreMsbBits(params *FindConfigMurmur3PartitionerIgnoreMsbBitsParams) (*FindConfigMurmur3PartitionerIgnoreMsbBitsOK, error)

FindConfigMurmur3PartitionerIgnoreMsbBits Number of most siginificant token bits to ignore in murmur3 partitioner; increase for very large clusters

func (*Client) FindConfigNativeTransportMaxFrameSizeInMb ¶

func (a *Client) FindConfigNativeTransportMaxFrameSizeInMb(params *FindConfigNativeTransportMaxFrameSizeInMbParams) (*FindConfigNativeTransportMaxFrameSizeInMbOK, error)

FindConfigNativeTransportMaxFrameSizeInMb The maximum size of allowed frame. Frame (requests) larger than this are rejected as invalid.

func (*Client) FindConfigNativeTransportMaxThreads ¶

func (a *Client) FindConfigNativeTransportMaxThreads(params *FindConfigNativeTransportMaxThreadsParams) (*FindConfigNativeTransportMaxThreadsOK, error)

FindConfigNativeTransportMaxThreads The maximum number of thread handling requests. The meaning is the same as rpc_max_threads. Default is different (128 versus unlimited). No corresponding native_transport_min_threads. Idle threads are stopped after 30 seconds.

func (*Client) FindConfigNativeTransportPort ¶

func (a *Client) FindConfigNativeTransportPort(params *FindConfigNativeTransportPortParams) (*FindConfigNativeTransportPortOK, error)

FindConfigNativeTransportPort Port on which the CQL native transport listens for clients.

func (*Client) FindConfigNativeTransportPortSsl ¶

func (a *Client) FindConfigNativeTransportPortSsl(params *FindConfigNativeTransportPortSslParams) (*FindConfigNativeTransportPortSslOK, error)

FindConfigNativeTransportPortSsl Port on which the CQL TLS native transport listens for clients.Enabling client encryption and keeping native_transport_port_ssl disabled will use encryptionfor native_transport_port. Setting native_transport_port_ssl to a different valuefrom native_transport_port will use encryption for native_transport_port_ssl whilekeeping native_transport_port unencrypted

func (*Client) FindConfigNumTokens ¶

func (a *Client) FindConfigNumTokens(params *FindConfigNumTokensParams) (*FindConfigNumTokensOK, error)

FindConfigNumTokens Defines the number of tokens randomly assigned to this node on the ring when using virtual nodes (vnodes). The more tokens, relative to other nodes, the larger the proportion of data that the node stores. Generally all nodes should have the same number of tokens assuming equal hardware capability. The recommended value is 256. If unspecified (#num_tokens), Scylla uses 1 (equivalent to #num_tokens : 1) for legacy compatibility and uses the initial_token setting. If not using vnodes, comment #num_tokens : 256 or set num_tokens : 1 and use initial_token. If you already have an existing cluster with one token per node and wish to migrate to vnodes, see Enabling virtual nodes on an existing production cluster. Note: If using DataStax Enterprise, the default setting of this property depends on the type of node and type of install.

func (*Client) FindConfigOverrideDecommission ¶

func (a *Client) FindConfigOverrideDecommission(params *FindConfigOverrideDecommissionParams) (*FindConfigOverrideDecommissionOK, error)

FindConfigOverrideDecommission Set true to force a decommissioned node to join the cluster

func (*Client) FindConfigPartitioner ¶

func (a *Client) FindConfigPartitioner(params *FindConfigPartitionerParams) (*FindConfigPartitionerOK, error)

FindConfigPartitioner Distributes rows (by partition key) across all nodes in the cluster. Any IPartitioner may be used, including your own as long as it is in the class path. For new clusters use the default partitioner. Scylla provides the following partitioners for backwards compatibility:

RandomPartitioner
ByteOrderedPartitioner
OrderPreservingPartitioner (deprecated)

Related information: Partitioners

func (*Client) FindConfigPermissionsCacheMaxEntries ¶

func (a *Client) FindConfigPermissionsCacheMaxEntries(params *FindConfigPermissionsCacheMaxEntriesParams) (*FindConfigPermissionsCacheMaxEntriesOK, error)

FindConfigPermissionsCacheMaxEntries Maximum cached permission entries. Must have a non-zero value if permissions caching is enabled (see a permissions_validity_in_ms description).

func (*Client) FindConfigPermissionsUpdateIntervalInMs ¶

func (a *Client) FindConfigPermissionsUpdateIntervalInMs(params *FindConfigPermissionsUpdateIntervalInMsParams) (*FindConfigPermissionsUpdateIntervalInMsOK, error)

FindConfigPermissionsUpdateIntervalInMs Refresh interval for permissions cache (if enabled). After this interval, cache entries become eligible for refresh. An async reload is scheduled every permissions_update_interval_in_ms time period and the old value is returned until it completes. If permissions_validity_in_ms has a non-zero value, then this property must also have a non-zero value. It's recommended to set this value to be at least 3 times smaller than the permissions_validity_in_ms.

func (*Client) FindConfigPermissionsValidityInMs ¶

func (a *Client) FindConfigPermissionsValidityInMs(params *FindConfigPermissionsValidityInMsParams) (*FindConfigPermissionsValidityInMsOK, error)

FindConfigPermissionsValidityInMs How long permissions in cache remain valid. Depending on the authorizer, such as CassandraAuthorizer, fetching permissions can be resource intensive. Permissions caching is disabled when this property is set to 0 or when AllowAllAuthorizer is used. The cached value is considered valid as long as both its value is not older than the permissions_validity_in_ms and the cached value has been read at least once during the permissions_validity_in_ms time frame. If any of these two conditions doesn't hold the cached value is going to be evicted from the cache. Related information: Object permissions

func (*Client) FindConfigPhiConvictThreshold ¶

func (a *Client) FindConfigPhiConvictThreshold(params *FindConfigPhiConvictThresholdParams) (*FindConfigPhiConvictThresholdOK, error)

FindConfigPhiConvictThreshold Adjusts the sensitivity of the failure detector on an exponential scale. Generally this setting never needs adjusting. Related information: Failure detection and recovery

func (*Client) FindConfigPreheatKernelPageCache ¶

func (a *Client) FindConfigPreheatKernelPageCache(params *FindConfigPreheatKernelPageCacheParams) (*FindConfigPreheatKernelPageCacheOK, error)

FindConfigPreheatKernelPageCache Enable or disable kernel page cache preheating from contents of the key cache after compaction. When enabled it preheats only first page (4KB) of each row to optimize for sequential access. It can be harmful for fat rows, see CASSANDRA-4937 for more details.

func (*Client) FindConfigPrometheusAddress ¶

func (a *Client) FindConfigPrometheusAddress(params *FindConfigPrometheusAddressParams) (*FindConfigPrometheusAddressOK, error)

FindConfigPrometheusAddress Prometheus listening address

func (*Client) FindConfigPrometheusPort ¶

func (a *Client) FindConfigPrometheusPort(params *FindConfigPrometheusPortParams) (*FindConfigPrometheusPortOK, error)

FindConfigPrometheusPort Prometheus port, set to zero to disable

func (*Client) FindConfigPrometheusPrefix ¶

func (a *Client) FindConfigPrometheusPrefix(params *FindConfigPrometheusPrefixParams) (*FindConfigPrometheusPrefixOK, error)

FindConfigPrometheusPrefix Set the prefix of the exported Prometheus metrics. Changing this will break Scylla's dashboard compatibility, do not change unless you know what you are doing.

func (*Client) FindConfigRPCAddress ¶

func (a *Client) FindConfigRPCAddress(params *FindConfigRPCAddressParams) (*FindConfigRPCAddressOK, error)

FindConfigRPCAddress The listen address for client connections (Thrift RPC service and native transport).Valid values are:

unset:   Resolves the address using the hostname configuration of the node. If left unset, the hostname must resolve to the IP address of this node using /etc/hostname, /etc/hosts, or DNS.
0.0.0.0 : Listens on all configured interfaces, but you must set the broadcast_rpc_address to a value other than 0.0.0.0.
IP address
hostname

Related information: Network

func (*Client) FindConfigRPCInterface ¶

func (a *Client) FindConfigRPCInterface(params *FindConfigRPCInterfaceParams) (*FindConfigRPCInterfaceOK, error)

FindConfigRPCInterface The listen address for client connections. Interfaces must correspond to a single address, IP aliasing is not supported. See rpc_address.

func (*Client) FindConfigRPCKeepalive ¶

func (a *Client) FindConfigRPCKeepalive(params *FindConfigRPCKeepaliveParams) (*FindConfigRPCKeepaliveOK, error)

FindConfigRPCKeepalive Enable or disable keepalive on client connections (RPC or native).

func (*Client) FindConfigRPCMaxThreads ¶

func (a *Client) FindConfigRPCMaxThreads(params *FindConfigRPCMaxThreadsParams) (*FindConfigRPCMaxThreadsOK, error)

FindConfigRPCMaxThreads Regardless of your choice of RPC server (rpc_server_type), the number of maximum requests in the RPC thread pool dictates how many concurrent requests are possible. However, if you are using the parameter sync in the rpc_server_type, it also dictates the number of clients that can be connected. For a large number of client connections, this could cause excessive memory usage for the thread stack. Connection pooling on the client side is highly recommended. Setting a maximum thread pool size acts as a safeguard against misbehaved clients. If the maximum is reached, Cassandra blocks additional connections until a client disconnects.

func (*Client) FindConfigRPCMinThreads ¶

func (a *Client) FindConfigRPCMinThreads(params *FindConfigRPCMinThreadsParams) (*FindConfigRPCMinThreadsOK, error)

FindConfigRPCMinThreads Sets the minimum thread pool size for remote procedure calls.

func (*Client) FindConfigRPCPort ¶

func (a *Client) FindConfigRPCPort(params *FindConfigRPCPortParams) (*FindConfigRPCPortOK, error)

FindConfigRPCPort Thrift port for client connections.

func (*Client) FindConfigRPCRecvBuffSizeInBytes ¶

func (a *Client) FindConfigRPCRecvBuffSizeInBytes(params *FindConfigRPCRecvBuffSizeInBytesParams) (*FindConfigRPCRecvBuffSizeInBytesOK, error)

FindConfigRPCRecvBuffSizeInBytes Sets the receiving socket buffer size for remote procedure calls.

func (*Client) FindConfigRPCSendBuffSizeInBytes ¶

func (a *Client) FindConfigRPCSendBuffSizeInBytes(params *FindConfigRPCSendBuffSizeInBytesParams) (*FindConfigRPCSendBuffSizeInBytesOK, error)

FindConfigRPCSendBuffSizeInBytes Sets the sending socket buffer size in bytes for remote procedure calls.

func (*Client) FindConfigRPCServerType ¶

func (a *Client) FindConfigRPCServerType(params *FindConfigRPCServerTypeParams) (*FindConfigRPCServerTypeOK, error)

FindConfigRPCServerType Cassandra provides three options for the RPC server. On Windows, sync is about 30% slower than hsha. On Linux, sync and hsha performance is about the same, but hsha uses less memory.

sync    (Default One thread per Thrift connection.) For a very large number of clients, memory is the limiting factor. On a 64-bit JVM, 180KB is the minimum stack size per thread and corresponds to your use of virtual memory. Physical memory may be limited depending on use of stack space.
hsh      Half synchronous, half asynchronous. All Thrift clients are handled asynchronously using a small number of threads that does not vary with the number of clients and thus scales well to many clients. The RPC requests are synchronous (one thread per active request).
         Note: When selecting this option, you must change the default value (unlimited) of rpc_max_threads.
Your own RPC server: You must provide a fully-qualified class name of an o.a.c.t.TServerFactory that can create a server instance.

func (*Client) FindConfigRangeRequestTimeoutInMs ¶

func (a *Client) FindConfigRangeRequestTimeoutInMs(params *FindConfigRangeRequestTimeoutInMsParams) (*FindConfigRangeRequestTimeoutInMsOK, error)

FindConfigRangeRequestTimeoutInMs The time in milliseconds that the coordinator waits for sequential or index scans to complete.

func (*Client) FindConfigReadRequestTimeoutInMs ¶

func (a *Client) FindConfigReadRequestTimeoutInMs(params *FindConfigReadRequestTimeoutInMsParams) (*FindConfigReadRequestTimeoutInMsOK, error)

FindConfigReadRequestTimeoutInMs The time that the coordinator waits for read operations to complete

func (*Client) FindConfigReduceCacheCapacityTo ¶

func (a *Client) FindConfigReduceCacheCapacityTo(params *FindConfigReduceCacheCapacityToParams) (*FindConfigReduceCacheCapacityToOK, error)

FindConfigReduceCacheCapacityTo Sets the size percentage to which maximum cache capacity is reduced when Java heap usage reaches the threshold defined by reduce_cache_sizes_at. Together with flush_largest_memtables_at, these properties constitute an emergency measure for preventing sudden out-of-memory (OOM) errors.

func (*Client) FindConfigReduceCacheSizesAt ¶

func (a *Client) FindConfigReduceCacheSizesAt(params *FindConfigReduceCacheSizesAtParams) (*FindConfigReduceCacheSizesAtOK, error)

FindConfigReduceCacheSizesAt When Java heap usage (after a full concurrent mark sweep (CMS) garbage collection) exceeds this percentage, Cassandra reduces the cache capacity to the fraction of the current size as specified by reduce_cache_capacity_to. To disable, set the value to 1.0.

func (*Client) FindConfigReplaceAddress ¶

func (a *Client) FindConfigReplaceAddress(params *FindConfigReplaceAddressParams) (*FindConfigReplaceAddressOK, error)

FindConfigReplaceAddress The listen_address or broadcast_address of the dead node to replace. Same as -Dcassandra.replace_address.

func (*Client) FindConfigReplaceAddressFirstBoot ¶

func (a *Client) FindConfigReplaceAddressFirstBoot(params *FindConfigReplaceAddressFirstBootParams) (*FindConfigReplaceAddressFirstBootOK, error)

FindConfigReplaceAddressFirstBoot Like replace_address option, but if the node has been bootstrapped successfully it will be ignored. Same as -Dcassandra.replace_address_first_boot.

func (*Client) FindConfigReplaceNode ¶

func (a *Client) FindConfigReplaceNode(params *FindConfigReplaceNodeParams) (*FindConfigReplaceNodeOK, error)

FindConfigReplaceNode The UUID of the node to replace. Same as -Dcassandra.replace_node in cssandra.

func (*Client) FindConfigReplaceToken ¶

func (a *Client) FindConfigReplaceToken(params *FindConfigReplaceTokenParams) (*FindConfigReplaceTokenOK, error)

FindConfigReplaceToken The tokens of the node to replace. Same as -Dcassandra.replace_token in cassandra.

func (*Client) FindConfigRequestScheduler ¶

func (a *Client) FindConfigRequestScheduler(params *FindConfigRequestSchedulerParams) (*FindConfigRequestSchedulerOK, error)

FindConfigRequestScheduler Defines a scheduler to handle incoming client requests according to a defined policy. This scheduler is useful for throttling client requests in single clusters containing multiple keyspaces. This parameter is specifically for requests from the client and does not affect inter-node communication. Valid values are:

org.apache.cassandra.scheduler.NoScheduler   No scheduling takes place.
org.apache.cassandra.scheduler.RoundRobinScheduler   Round robin of client requests to a node with a separate queue for each request_scheduler_id property.
A Java class that implements the RequestScheduler interface.

func (*Client) FindConfigRequestSchedulerID ¶

func (a *Client) FindConfigRequestSchedulerID(params *FindConfigRequestSchedulerIDParams) (*FindConfigRequestSchedulerIDOK, error)

FindConfigRequestSchedulerID An identifier on which to perform request scheduling. Currently the only valid value is keyspace. See weights.

func (*Client) FindConfigRequestSchedulerOptions ¶

func (a *Client) FindConfigRequestSchedulerOptions(params *FindConfigRequestSchedulerOptionsParams) (*FindConfigRequestSchedulerOptionsOK, error)

FindConfigRequestSchedulerOptions Contains a list of properties that define configuration options for request_scheduler:

throttle_limit: The number of in-flight requests per client. Requests beyond this limit are queued up until running requests complete. Recommended value is ((concurrent_reads + concurrent_writes) Ă— 2)
default_weight: (Default: 1 **)  How many requests are handled during each turn of the RoundRobin.
weights: (Default: Keyspace: 1)  Takes a list of keyspaces. It sets how many requests are handled during each turn of the RoundRobin, based on the request_scheduler_id.

func (*Client) FindConfigRequestTimeoutInMs ¶

func (a *Client) FindConfigRequestTimeoutInMs(params *FindConfigRequestTimeoutInMsParams) (*FindConfigRequestTimeoutInMsOK, error)

FindConfigRequestTimeoutInMs The default timeout for other, miscellaneous operations. Related information: About hinted handoff writes

func (*Client) FindConfigRingDelayMs ¶

func (a *Client) FindConfigRingDelayMs(params *FindConfigRingDelayMsParams) (*FindConfigRingDelayMsOK, error)

FindConfigRingDelayMs Time a node waits to hear from other nodes before joining the ring in milliseconds. Same as -Dcassandra.ring_delay_ms in cassandra.

func (*Client) FindConfigRoleManager ¶

func (a *Client) FindConfigRoleManager(params *FindConfigRoleManagerParams) (*FindConfigRoleManagerOK, error)

FindConfigRoleManager The role-management backend, used to maintain grantts and memberships between roles. The available role-managers are:

CassandraRoleManager : Stores role data in the system_auth keyspace.

func (*Client) FindConfigRowCacheKeysToSave ¶

func (a *Client) FindConfigRowCacheKeysToSave(params *FindConfigRowCacheKeysToSaveParams) (*FindConfigRowCacheKeysToSaveOK, error)

FindConfigRowCacheKeysToSave Number of keys from the row cache to save.

func (*Client) FindConfigRowCacheSavePeriod ¶

func (a *Client) FindConfigRowCacheSavePeriod(params *FindConfigRowCacheSavePeriodParams) (*FindConfigRowCacheSavePeriodOK, error)

FindConfigRowCacheSavePeriod Duration in seconds that rows are saved in cache. Caches are saved to saved_caches_directory.

func (*Client) FindConfigRowCacheSizeInMb ¶

func (a *Client) FindConfigRowCacheSizeInMb(params *FindConfigRowCacheSizeInMbParams) (*FindConfigRowCacheSizeInMbOK, error)

FindConfigRowCacheSizeInMb Maximum size of the row cache in memory. Row cache can save more time than key_cache_size_in_mb, but is space-intensive because it contains the entire row. Use the row cache only for hot rows or static rows. If you reduce the size, you may not get you hottest keys loaded on start up.

func (*Client) FindConfigSavedCachesDirectory ¶

func (a *Client) FindConfigSavedCachesDirectory(params *FindConfigSavedCachesDirectoryParams) (*FindConfigSavedCachesDirectoryOK, error)

FindConfigSavedCachesDirectory The directory location where table key and row caches are stored.

func (*Client) FindConfigSeedProvider ¶

func (a *Client) FindConfigSeedProvider(params *FindConfigSeedProviderParams) (*FindConfigSeedProviderOK, error)

FindConfigSeedProvider The addresses of hosts deemed contact points. Scylla nodes use the -seeds list to find each other and learn the topology of the ring.

class_name (Default: org.apache.cassandra.locator.SimpleSeedProvider)
 The class within Scylla that handles the seed logic. It can be customized, but this is typically not required.
 - seeds (Default: 127.0.0.1)    A comma-delimited list of IP addresses used by gossip for bootstrapping new nodes joining a cluster. When running multiple nodes, you must change the list from the default value. In multiple data-center clusters, the seed list should include at least one node from each data center (replication group). More than a single seed node per data center is recommended for fault tolerance. Otherwise, gossip has to communicate with another data center when bootstrapping a node. Making every node a seed node is not recommended because of increased maintenance and reduced gossip performance. Gossip optimization is not critical, but it is recommended to use a small seed list (approximately three nodes per data center).

Related information: Initializing a multiple node cluster (single data center) and Initializing a multiple node cluster (multiple data centers).

func (*Client) FindConfigServerEncryptionOptions ¶

func (a *Client) FindConfigServerEncryptionOptions(params *FindConfigServerEncryptionOptionsParams) (*FindConfigServerEncryptionOptionsOK, error)

FindConfigServerEncryptionOptions Enable or disable inter-node encryption. You must also generate keys and provide the appropriate key and trust store locations and passwords. No custom encryption options are currently enabled. The available options are:

internode_encryption : (Default: none ) Enable or disable encryption of inter-node communication using the TLS_RSA_WITH_AES_128_CBC_SHA cipher suite for authentication, key exchange, and encryption of data transfers. The available inter-node options are:

all : Encrypt all inter-node communications.
none : No encryption.
dc : Encrypt the traffic between the data centers (server only).
rack : Encrypt the traffic between the racks(server only).

certificate : (Default: conf/scylla.crt) The location of a PEM-encoded x509 certificate used to identify and encrypt the internode communication. keyfile : (Default: conf/scylla.key) PEM Key file associated with certificate. truststore : (Default: <system truststore> ) Location of the truststore containing the trusted certificate for authenticating remote servers.

The advanced settings are:

priority_string : GnuTLS priority string controlling TLS algorithms used/allowed.
require_client_auth : (Default: false ) Enables or disables certificate authentication.

Related information: Node-to-node encryption

func (*Client) FindConfigShadowRoundMs ¶

func (a *Client) FindConfigShadowRoundMs(params *FindConfigShadowRoundMsParams) (*FindConfigShadowRoundMsOK, error)

FindConfigShadowRoundMs The maximum gossip shadow round time. Can be used to reduce the gossip feature check time during node boot up.

func (*Client) FindConfigShutdownAnnounceInMs ¶

func (a *Client) FindConfigShutdownAnnounceInMs(params *FindConfigShutdownAnnounceInMsParams) (*FindConfigShutdownAnnounceInMsOK, error)

FindConfigShutdownAnnounceInMs Time a node waits after sending gossip shutdown message in milliseconds. Same as -Dcassandra.shutdown_announce_in_ms in cassandra.

func (*Client) FindConfigSkipWaitForGossipToSettle ¶

func (a *Client) FindConfigSkipWaitForGossipToSettle(params *FindConfigSkipWaitForGossipToSettleParams) (*FindConfigSkipWaitForGossipToSettleOK, error)

FindConfigSkipWaitForGossipToSettle An integer to configure the wait for gossip to settle. -1: wait normally, 0: do not wait at all, n: wait for at most n polls. Same as -Dcassandra.skip_wait_for_gossip_to_settle in cassandra.

func (*Client) FindConfigSnapshotBeforeCompaction ¶

func (a *Client) FindConfigSnapshotBeforeCompaction(params *FindConfigSnapshotBeforeCompactionParams) (*FindConfigSnapshotBeforeCompactionOK, error)

FindConfigSnapshotBeforeCompaction Enable or disable taking a snapshot before each compaction. This option is useful to back up data when there is a data format change. Be careful using this option because Cassandra does not clean up older snapshots automatically. Related information: Configuring compaction

func (*Client) FindConfigSslStoragePort ¶

func (a *Client) FindConfigSslStoragePort(params *FindConfigSslStoragePortParams) (*FindConfigSslStoragePortOK, error)

FindConfigSslStoragePort The SSL port for encrypted communication. Unused unless enabled in encryption_options.

func (*Client) FindConfigSstablePreemptiveOpenIntervalInMb ¶

func (a *Client) FindConfigSstablePreemptiveOpenIntervalInMb(params *FindConfigSstablePreemptiveOpenIntervalInMbParams) (*FindConfigSstablePreemptiveOpenIntervalInMbOK, error)

FindConfigSstablePreemptiveOpenIntervalInMb When compacting, the replacement opens SSTables before they are completely written and uses in place of the prior SSTables for any range previously written. This setting helps to smoothly transfer reads between the SSTables by reducing page cache churn and keeps hot rows hot.

func (*Client) FindConfigSstableSummaryRatio ¶

func (a *Client) FindConfigSstableSummaryRatio(params *FindConfigSstableSummaryRatioParams) (*FindConfigSstableSummaryRatioOK, error)

FindConfigSstableSummaryRatio Enforces that 1 byte of summary is written for every N (2000 by default) bytes written to data file. Value must be between 0 and 1.

func (*Client) FindConfigStartNativeTransport ¶

func (a *Client) FindConfigStartNativeTransport(params *FindConfigStartNativeTransportParams) (*FindConfigStartNativeTransportOK, error)

FindConfigStartNativeTransport Enable or disable the native transport server. Uses the same address as the rpc_address, but the port is different from the rpc_port. See native_transport_port.

func (*Client) FindConfigStartRPC ¶

func (a *Client) FindConfigStartRPC(params *FindConfigStartRPCParams) (*FindConfigStartRPCOK, error)

FindConfigStartRPC Starts the Thrift RPC server

func (*Client) FindConfigStoragePort ¶

func (a *Client) FindConfigStoragePort(params *FindConfigStoragePortParams) (*FindConfigStoragePortOK, error)

FindConfigStoragePort The port for inter-node communication.

func (*Client) FindConfigStreamThroughputOutboundMegabitsPerSec ¶

func (a *Client) FindConfigStreamThroughputOutboundMegabitsPerSec(params *FindConfigStreamThroughputOutboundMegabitsPerSecParams) (*FindConfigStreamThroughputOutboundMegabitsPerSecOK, error)

FindConfigStreamThroughputOutboundMegabitsPerSec Throttles all outbound streaming file transfers on a node to the specified throughput. Cassandra does mostly sequential I/O when streaming data during bootstrap or repair, which can lead to saturating the network connection and degrading client (RPC) performance.

func (*Client) FindConfigStreamingSocketTimeoutInMs ¶

func (a *Client) FindConfigStreamingSocketTimeoutInMs(params *FindConfigStreamingSocketTimeoutInMsParams) (*FindConfigStreamingSocketTimeoutInMsOK, error)

FindConfigStreamingSocketTimeoutInMs Enable or disable socket timeout for streaming operations. When a timeout occurs during streaming, streaming is retried from the start of the current file. Avoid setting this value too low, as it can result in a significant amount of data re-streaming.

func (*Client) FindConfigThriftFramedTransportSizeInMb ¶

func (a *Client) FindConfigThriftFramedTransportSizeInMb(params *FindConfigThriftFramedTransportSizeInMbParams) (*FindConfigThriftFramedTransportSizeInMbOK, error)

FindConfigThriftFramedTransportSizeInMb Frame size (maximum field length) for Thrift. The frame is the row or part of the row the application is inserting.

func (*Client) FindConfigThriftMaxMessageLengthInMb ¶

func (a *Client) FindConfigThriftMaxMessageLengthInMb(params *FindConfigThriftMaxMessageLengthInMbParams) (*FindConfigThriftMaxMessageLengthInMbOK, error)

FindConfigThriftMaxMessageLengthInMb The maximum length of a Thrift message in megabytes, including all fields and internal Thrift overhead (1 byte of overhead for each frame). Message length is usually used in conjunction with batches. A frame length greater than or equal to 24 accommodates a batch with four inserts, each of which is 24 bytes. The required message length is greater than or equal to 24+24+24+24+4 (number of frames).

func (*Client) FindConfigTombstoneFailureThreshold ¶

func (a *Client) FindConfigTombstoneFailureThreshold(params *FindConfigTombstoneFailureThresholdParams) (*FindConfigTombstoneFailureThresholdOK, error)

FindConfigTombstoneFailureThreshold The maximum number of tombstones a query can scan before aborting.

func (*Client) FindConfigTombstoneWarnThreshold ¶

func (a *Client) FindConfigTombstoneWarnThreshold(params *FindConfigTombstoneWarnThresholdParams) (*FindConfigTombstoneWarnThresholdOK, error)

FindConfigTombstoneWarnThreshold The maximum number of tombstones a query can scan before warning.

func (*Client) FindConfigTrickleFsync ¶

func (a *Client) FindConfigTrickleFsync(params *FindConfigTrickleFsyncParams) (*FindConfigTrickleFsyncOK, error)

FindConfigTrickleFsync When doing sequential writing, enabling this option tells fsync to force the operating system to flush the dirty buffers at a set interval trickle_fsync_interval_in_kb. Enable this parameter to avoid sudden dirty buffer flushing from impacting read latencies. Recommended to use on SSDs, but not on HDDs.

func (*Client) FindConfigTrickleFsyncIntervalInKb ¶

func (a *Client) FindConfigTrickleFsyncIntervalInKb(params *FindConfigTrickleFsyncIntervalInKbParams) (*FindConfigTrickleFsyncIntervalInKbOK, error)

FindConfigTrickleFsyncIntervalInKb Sets the size of the fsync in kilobytes.

func (*Client) FindConfigTruncateRequestTimeoutInMs ¶

func (a *Client) FindConfigTruncateRequestTimeoutInMs(params *FindConfigTruncateRequestTimeoutInMsParams) (*FindConfigTruncateRequestTimeoutInMsOK, error)

FindConfigTruncateRequestTimeoutInMs The time that the coordinator waits for truncates (remove all data from a table) to complete. The long default value allows for a snapshot to be taken before removing the data. If auto_snapshot is disabled (not recommended), you can reduce this time.

func (*Client) FindConfigViewBuilding ¶

func (a *Client) FindConfigViewBuilding(params *FindConfigViewBuildingParams) (*FindConfigViewBuildingOK, error)

FindConfigViewBuilding Enable view building; should only be set to false when the node is experience issues due to view building

func (*Client) FindConfigViewHintsDirectory ¶

func (a *Client) FindConfigViewHintsDirectory(params *FindConfigViewHintsDirectoryParams) (*FindConfigViewHintsDirectoryOK, error)

FindConfigViewHintsDirectory The directory where materialized-view updates are stored while a view replica is unreachable.

func (*Client) FindConfigVirtualDirtySoftLimit ¶

func (a *Client) FindConfigVirtualDirtySoftLimit(params *FindConfigVirtualDirtySoftLimitParams) (*FindConfigVirtualDirtySoftLimitOK, error)

FindConfigVirtualDirtySoftLimit Soft limit of virtual dirty memory expressed as a portion of the hard limit

func (*Client) FindConfigVolatileSystemKeyspaceForTesting ¶

func (a *Client) FindConfigVolatileSystemKeyspaceForTesting(params *FindConfigVolatileSystemKeyspaceForTestingParams) (*FindConfigVolatileSystemKeyspaceForTestingOK, error)

FindConfigVolatileSystemKeyspaceForTesting Don't persist system keyspace - testing only!

func (*Client) FindConfigWriteRequestTimeoutInMs ¶

func (a *Client) FindConfigWriteRequestTimeoutInMs(params *FindConfigWriteRequestTimeoutInMsParams) (*FindConfigWriteRequestTimeoutInMsOK, error)

FindConfigWriteRequestTimeoutInMs The time in milliseconds that the coordinator waits for write operations to complete. Related information: About hinted handoff writes

func (*Client) SetTransport ¶

func (a *Client) SetTransport(transport runtime.ClientTransport)

SetTransport changes the transport on the client

type FindConfigAPIAddressDefault ¶

type FindConfigAPIAddressDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAPIAddressDefault handles this case with default header values.

unexpected error

func NewFindConfigAPIAddressDefault ¶

func NewFindConfigAPIAddressDefault(code int) *FindConfigAPIAddressDefault

NewFindConfigAPIAddressDefault creates a FindConfigAPIAddressDefault with default headers values

func (*FindConfigAPIAddressDefault) Code ¶

func (o *FindConfigAPIAddressDefault) Code() int

Code gets the status code for the find config api address default response

func (*FindConfigAPIAddressDefault) Error ¶

func (*FindConfigAPIAddressDefault) GetPayload ¶

type FindConfigAPIAddressOK ¶

type FindConfigAPIAddressOK struct {
	Payload string
}

FindConfigAPIAddressOK handles this case with default header values.

Config value

func NewFindConfigAPIAddressOK ¶

func NewFindConfigAPIAddressOK() *FindConfigAPIAddressOK

NewFindConfigAPIAddressOK creates a FindConfigAPIAddressOK with default headers values

func (*FindConfigAPIAddressOK) GetPayload ¶

func (o *FindConfigAPIAddressOK) GetPayload() string

type FindConfigAPIAddressParams ¶

type FindConfigAPIAddressParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAPIAddressParams contains all the parameters to send to the API endpoint for the find config api address operation typically these are written to a http.Request

func NewFindConfigAPIAddressParams ¶

func NewFindConfigAPIAddressParams() *FindConfigAPIAddressParams

NewFindConfigAPIAddressParams creates a new FindConfigAPIAddressParams object with the default values initialized.

func NewFindConfigAPIAddressParamsWithContext ¶

func NewFindConfigAPIAddressParamsWithContext(ctx context.Context) *FindConfigAPIAddressParams

NewFindConfigAPIAddressParamsWithContext creates a new FindConfigAPIAddressParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAPIAddressParamsWithHTTPClient ¶

func NewFindConfigAPIAddressParamsWithHTTPClient(client *http.Client) *FindConfigAPIAddressParams

NewFindConfigAPIAddressParamsWithHTTPClient creates a new FindConfigAPIAddressParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAPIAddressParamsWithTimeout ¶

func NewFindConfigAPIAddressParamsWithTimeout(timeout time.Duration) *FindConfigAPIAddressParams

NewFindConfigAPIAddressParamsWithTimeout creates a new FindConfigAPIAddressParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAPIAddressParams) SetContext ¶

func (o *FindConfigAPIAddressParams) SetContext(ctx context.Context)

SetContext adds the context to the find config api address params

func (*FindConfigAPIAddressParams) SetHTTPClient ¶

func (o *FindConfigAPIAddressParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config api address params

func (*FindConfigAPIAddressParams) SetTimeout ¶

func (o *FindConfigAPIAddressParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config api address params

func (*FindConfigAPIAddressParams) WithContext ¶

WithContext adds the context to the find config api address params

func (*FindConfigAPIAddressParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config api address params

func (*FindConfigAPIAddressParams) WithTimeout ¶

WithTimeout adds the timeout to the find config api address params

func (*FindConfigAPIAddressParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAPIAddressReader ¶

type FindConfigAPIAddressReader struct {
	// contains filtered or unexported fields
}

FindConfigAPIAddressReader is a Reader for the FindConfigAPIAddress structure.

func (*FindConfigAPIAddressReader) ReadResponse ¶

func (o *FindConfigAPIAddressReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAPIDocDirDefault ¶

type FindConfigAPIDocDirDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAPIDocDirDefault handles this case with default header values.

unexpected error

func NewFindConfigAPIDocDirDefault ¶

func NewFindConfigAPIDocDirDefault(code int) *FindConfigAPIDocDirDefault

NewFindConfigAPIDocDirDefault creates a FindConfigAPIDocDirDefault with default headers values

func (*FindConfigAPIDocDirDefault) Code ¶

func (o *FindConfigAPIDocDirDefault) Code() int

Code gets the status code for the find config api doc dir default response

func (*FindConfigAPIDocDirDefault) Error ¶

func (*FindConfigAPIDocDirDefault) GetPayload ¶

func (o *FindConfigAPIDocDirDefault) GetPayload() *models.ErrorModel

type FindConfigAPIDocDirOK ¶

type FindConfigAPIDocDirOK struct {
	Payload string
}

FindConfigAPIDocDirOK handles this case with default header values.

Config value

func NewFindConfigAPIDocDirOK ¶

func NewFindConfigAPIDocDirOK() *FindConfigAPIDocDirOK

NewFindConfigAPIDocDirOK creates a FindConfigAPIDocDirOK with default headers values

func (*FindConfigAPIDocDirOK) GetPayload ¶

func (o *FindConfigAPIDocDirOK) GetPayload() string

type FindConfigAPIDocDirParams ¶

type FindConfigAPIDocDirParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAPIDocDirParams contains all the parameters to send to the API endpoint for the find config api doc dir operation typically these are written to a http.Request

func NewFindConfigAPIDocDirParams ¶

func NewFindConfigAPIDocDirParams() *FindConfigAPIDocDirParams

NewFindConfigAPIDocDirParams creates a new FindConfigAPIDocDirParams object with the default values initialized.

func NewFindConfigAPIDocDirParamsWithContext ¶

func NewFindConfigAPIDocDirParamsWithContext(ctx context.Context) *FindConfigAPIDocDirParams

NewFindConfigAPIDocDirParamsWithContext creates a new FindConfigAPIDocDirParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAPIDocDirParamsWithHTTPClient ¶

func NewFindConfigAPIDocDirParamsWithHTTPClient(client *http.Client) *FindConfigAPIDocDirParams

NewFindConfigAPIDocDirParamsWithHTTPClient creates a new FindConfigAPIDocDirParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAPIDocDirParamsWithTimeout ¶

func NewFindConfigAPIDocDirParamsWithTimeout(timeout time.Duration) *FindConfigAPIDocDirParams

NewFindConfigAPIDocDirParamsWithTimeout creates a new FindConfigAPIDocDirParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAPIDocDirParams) SetContext ¶

func (o *FindConfigAPIDocDirParams) SetContext(ctx context.Context)

SetContext adds the context to the find config api doc dir params

func (*FindConfigAPIDocDirParams) SetHTTPClient ¶

func (o *FindConfigAPIDocDirParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config api doc dir params

func (*FindConfigAPIDocDirParams) SetTimeout ¶

func (o *FindConfigAPIDocDirParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config api doc dir params

func (*FindConfigAPIDocDirParams) WithContext ¶

WithContext adds the context to the find config api doc dir params

func (*FindConfigAPIDocDirParams) WithHTTPClient ¶

func (o *FindConfigAPIDocDirParams) WithHTTPClient(client *http.Client) *FindConfigAPIDocDirParams

WithHTTPClient adds the HTTPClient to the find config api doc dir params

func (*FindConfigAPIDocDirParams) WithTimeout ¶

WithTimeout adds the timeout to the find config api doc dir params

func (*FindConfigAPIDocDirParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAPIDocDirReader ¶

type FindConfigAPIDocDirReader struct {
	// contains filtered or unexported fields
}

FindConfigAPIDocDirReader is a Reader for the FindConfigAPIDocDir structure.

func (*FindConfigAPIDocDirReader) ReadResponse ¶

func (o *FindConfigAPIDocDirReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAPIPortDefault ¶

type FindConfigAPIPortDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAPIPortDefault handles this case with default header values.

unexpected error

func NewFindConfigAPIPortDefault ¶

func NewFindConfigAPIPortDefault(code int) *FindConfigAPIPortDefault

NewFindConfigAPIPortDefault creates a FindConfigAPIPortDefault with default headers values

func (*FindConfigAPIPortDefault) Code ¶

func (o *FindConfigAPIPortDefault) Code() int

Code gets the status code for the find config api port default response

func (*FindConfigAPIPortDefault) Error ¶

func (o *FindConfigAPIPortDefault) Error() string

func (*FindConfigAPIPortDefault) GetPayload ¶

func (o *FindConfigAPIPortDefault) GetPayload() *models.ErrorModel

type FindConfigAPIPortOK ¶

type FindConfigAPIPortOK struct {
	Payload int64
}

FindConfigAPIPortOK handles this case with default header values.

Config value

func NewFindConfigAPIPortOK ¶

func NewFindConfigAPIPortOK() *FindConfigAPIPortOK

NewFindConfigAPIPortOK creates a FindConfigAPIPortOK with default headers values

func (*FindConfigAPIPortOK) GetPayload ¶

func (o *FindConfigAPIPortOK) GetPayload() int64

type FindConfigAPIPortParams ¶

type FindConfigAPIPortParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAPIPortParams contains all the parameters to send to the API endpoint for the find config api port operation typically these are written to a http.Request

func NewFindConfigAPIPortParams ¶

func NewFindConfigAPIPortParams() *FindConfigAPIPortParams

NewFindConfigAPIPortParams creates a new FindConfigAPIPortParams object with the default values initialized.

func NewFindConfigAPIPortParamsWithContext ¶

func NewFindConfigAPIPortParamsWithContext(ctx context.Context) *FindConfigAPIPortParams

NewFindConfigAPIPortParamsWithContext creates a new FindConfigAPIPortParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAPIPortParamsWithHTTPClient ¶

func NewFindConfigAPIPortParamsWithHTTPClient(client *http.Client) *FindConfigAPIPortParams

NewFindConfigAPIPortParamsWithHTTPClient creates a new FindConfigAPIPortParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAPIPortParamsWithTimeout ¶

func NewFindConfigAPIPortParamsWithTimeout(timeout time.Duration) *FindConfigAPIPortParams

NewFindConfigAPIPortParamsWithTimeout creates a new FindConfigAPIPortParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAPIPortParams) SetContext ¶

func (o *FindConfigAPIPortParams) SetContext(ctx context.Context)

SetContext adds the context to the find config api port params

func (*FindConfigAPIPortParams) SetHTTPClient ¶

func (o *FindConfigAPIPortParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config api port params

func (*FindConfigAPIPortParams) SetTimeout ¶

func (o *FindConfigAPIPortParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config api port params

func (*FindConfigAPIPortParams) WithContext ¶

WithContext adds the context to the find config api port params

func (*FindConfigAPIPortParams) WithHTTPClient ¶

func (o *FindConfigAPIPortParams) WithHTTPClient(client *http.Client) *FindConfigAPIPortParams

WithHTTPClient adds the HTTPClient to the find config api port params

func (*FindConfigAPIPortParams) WithTimeout ¶

WithTimeout adds the timeout to the find config api port params

func (*FindConfigAPIPortParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAPIPortReader ¶

type FindConfigAPIPortReader struct {
	// contains filtered or unexported fields
}

FindConfigAPIPortReader is a Reader for the FindConfigAPIPort structure.

func (*FindConfigAPIPortReader) ReadResponse ¶

func (o *FindConfigAPIPortReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAPIUIDirDefault ¶

type FindConfigAPIUIDirDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAPIUIDirDefault handles this case with default header values.

unexpected error

func NewFindConfigAPIUIDirDefault ¶

func NewFindConfigAPIUIDirDefault(code int) *FindConfigAPIUIDirDefault

NewFindConfigAPIUIDirDefault creates a FindConfigAPIUIDirDefault with default headers values

func (*FindConfigAPIUIDirDefault) Code ¶

func (o *FindConfigAPIUIDirDefault) Code() int

Code gets the status code for the find config api ui dir default response

func (*FindConfigAPIUIDirDefault) Error ¶

func (o *FindConfigAPIUIDirDefault) Error() string

func (*FindConfigAPIUIDirDefault) GetPayload ¶

func (o *FindConfigAPIUIDirDefault) GetPayload() *models.ErrorModel

type FindConfigAPIUIDirOK ¶

type FindConfigAPIUIDirOK struct {
	Payload string
}

FindConfigAPIUIDirOK handles this case with default header values.

Config value

func NewFindConfigAPIUIDirOK ¶

func NewFindConfigAPIUIDirOK() *FindConfigAPIUIDirOK

NewFindConfigAPIUIDirOK creates a FindConfigAPIUIDirOK with default headers values

func (*FindConfigAPIUIDirOK) GetPayload ¶

func (o *FindConfigAPIUIDirOK) GetPayload() string

type FindConfigAPIUIDirParams ¶

type FindConfigAPIUIDirParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAPIUIDirParams contains all the parameters to send to the API endpoint for the find config api ui dir operation typically these are written to a http.Request

func NewFindConfigAPIUIDirParams ¶

func NewFindConfigAPIUIDirParams() *FindConfigAPIUIDirParams

NewFindConfigAPIUIDirParams creates a new FindConfigAPIUIDirParams object with the default values initialized.

func NewFindConfigAPIUIDirParamsWithContext ¶

func NewFindConfigAPIUIDirParamsWithContext(ctx context.Context) *FindConfigAPIUIDirParams

NewFindConfigAPIUIDirParamsWithContext creates a new FindConfigAPIUIDirParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAPIUIDirParamsWithHTTPClient ¶

func NewFindConfigAPIUIDirParamsWithHTTPClient(client *http.Client) *FindConfigAPIUIDirParams

NewFindConfigAPIUIDirParamsWithHTTPClient creates a new FindConfigAPIUIDirParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAPIUIDirParamsWithTimeout ¶

func NewFindConfigAPIUIDirParamsWithTimeout(timeout time.Duration) *FindConfigAPIUIDirParams

NewFindConfigAPIUIDirParamsWithTimeout creates a new FindConfigAPIUIDirParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAPIUIDirParams) SetContext ¶

func (o *FindConfigAPIUIDirParams) SetContext(ctx context.Context)

SetContext adds the context to the find config api ui dir params

func (*FindConfigAPIUIDirParams) SetHTTPClient ¶

func (o *FindConfigAPIUIDirParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config api ui dir params

func (*FindConfigAPIUIDirParams) SetTimeout ¶

func (o *FindConfigAPIUIDirParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config api ui dir params

func (*FindConfigAPIUIDirParams) WithContext ¶

WithContext adds the context to the find config api ui dir params

func (*FindConfigAPIUIDirParams) WithHTTPClient ¶

func (o *FindConfigAPIUIDirParams) WithHTTPClient(client *http.Client) *FindConfigAPIUIDirParams

WithHTTPClient adds the HTTPClient to the find config api ui dir params

func (*FindConfigAPIUIDirParams) WithTimeout ¶

WithTimeout adds the timeout to the find config api ui dir params

func (*FindConfigAPIUIDirParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAPIUIDirReader ¶

type FindConfigAPIUIDirReader struct {
	// contains filtered or unexported fields
}

FindConfigAPIUIDirReader is a Reader for the FindConfigAPIUIDir structure.

func (*FindConfigAPIUIDirReader) ReadResponse ¶

func (o *FindConfigAPIUIDirReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAbortOnLsaBadAllocDefault ¶

type FindConfigAbortOnLsaBadAllocDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAbortOnLsaBadAllocDefault handles this case with default header values.

unexpected error

func NewFindConfigAbortOnLsaBadAllocDefault ¶

func NewFindConfigAbortOnLsaBadAllocDefault(code int) *FindConfigAbortOnLsaBadAllocDefault

NewFindConfigAbortOnLsaBadAllocDefault creates a FindConfigAbortOnLsaBadAllocDefault with default headers values

func (*FindConfigAbortOnLsaBadAllocDefault) Code ¶

Code gets the status code for the find config abort on lsa bad alloc default response

func (*FindConfigAbortOnLsaBadAllocDefault) Error ¶

func (*FindConfigAbortOnLsaBadAllocDefault) GetPayload ¶

type FindConfigAbortOnLsaBadAllocOK ¶

type FindConfigAbortOnLsaBadAllocOK struct {
	Payload bool
}

FindConfigAbortOnLsaBadAllocOK handles this case with default header values.

Config value

func NewFindConfigAbortOnLsaBadAllocOK ¶

func NewFindConfigAbortOnLsaBadAllocOK() *FindConfigAbortOnLsaBadAllocOK

NewFindConfigAbortOnLsaBadAllocOK creates a FindConfigAbortOnLsaBadAllocOK with default headers values

func (*FindConfigAbortOnLsaBadAllocOK) GetPayload ¶

func (o *FindConfigAbortOnLsaBadAllocOK) GetPayload() bool

type FindConfigAbortOnLsaBadAllocParams ¶

type FindConfigAbortOnLsaBadAllocParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAbortOnLsaBadAllocParams contains all the parameters to send to the API endpoint for the find config abort on lsa bad alloc operation typically these are written to a http.Request

func NewFindConfigAbortOnLsaBadAllocParams ¶

func NewFindConfigAbortOnLsaBadAllocParams() *FindConfigAbortOnLsaBadAllocParams

NewFindConfigAbortOnLsaBadAllocParams creates a new FindConfigAbortOnLsaBadAllocParams object with the default values initialized.

func NewFindConfigAbortOnLsaBadAllocParamsWithContext ¶

func NewFindConfigAbortOnLsaBadAllocParamsWithContext(ctx context.Context) *FindConfigAbortOnLsaBadAllocParams

NewFindConfigAbortOnLsaBadAllocParamsWithContext creates a new FindConfigAbortOnLsaBadAllocParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAbortOnLsaBadAllocParamsWithHTTPClient ¶

func NewFindConfigAbortOnLsaBadAllocParamsWithHTTPClient(client *http.Client) *FindConfigAbortOnLsaBadAllocParams

NewFindConfigAbortOnLsaBadAllocParamsWithHTTPClient creates a new FindConfigAbortOnLsaBadAllocParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAbortOnLsaBadAllocParamsWithTimeout ¶

func NewFindConfigAbortOnLsaBadAllocParamsWithTimeout(timeout time.Duration) *FindConfigAbortOnLsaBadAllocParams

NewFindConfigAbortOnLsaBadAllocParamsWithTimeout creates a new FindConfigAbortOnLsaBadAllocParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAbortOnLsaBadAllocParams) SetContext ¶

SetContext adds the context to the find config abort on lsa bad alloc params

func (*FindConfigAbortOnLsaBadAllocParams) SetHTTPClient ¶

func (o *FindConfigAbortOnLsaBadAllocParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config abort on lsa bad alloc params

func (*FindConfigAbortOnLsaBadAllocParams) SetTimeout ¶

func (o *FindConfigAbortOnLsaBadAllocParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config abort on lsa bad alloc params

func (*FindConfigAbortOnLsaBadAllocParams) WithContext ¶

WithContext adds the context to the find config abort on lsa bad alloc params

func (*FindConfigAbortOnLsaBadAllocParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config abort on lsa bad alloc params

func (*FindConfigAbortOnLsaBadAllocParams) WithTimeout ¶

WithTimeout adds the timeout to the find config abort on lsa bad alloc params

func (*FindConfigAbortOnLsaBadAllocParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAbortOnLsaBadAllocReader ¶

type FindConfigAbortOnLsaBadAllocReader struct {
	// contains filtered or unexported fields
}

FindConfigAbortOnLsaBadAllocReader is a Reader for the FindConfigAbortOnLsaBadAlloc structure.

func (*FindConfigAbortOnLsaBadAllocReader) ReadResponse ¶

func (o *FindConfigAbortOnLsaBadAllocReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAuthenticatorDefault ¶

type FindConfigAuthenticatorDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAuthenticatorDefault handles this case with default header values.

unexpected error

func NewFindConfigAuthenticatorDefault ¶

func NewFindConfigAuthenticatorDefault(code int) *FindConfigAuthenticatorDefault

NewFindConfigAuthenticatorDefault creates a FindConfigAuthenticatorDefault with default headers values

func (*FindConfigAuthenticatorDefault) Code ¶

Code gets the status code for the find config authenticator default response

func (*FindConfigAuthenticatorDefault) Error ¶

func (*FindConfigAuthenticatorDefault) GetPayload ¶

type FindConfigAuthenticatorOK ¶

type FindConfigAuthenticatorOK struct {
	Payload string
}

FindConfigAuthenticatorOK handles this case with default header values.

Config value

func NewFindConfigAuthenticatorOK ¶

func NewFindConfigAuthenticatorOK() *FindConfigAuthenticatorOK

NewFindConfigAuthenticatorOK creates a FindConfigAuthenticatorOK with default headers values

func (*FindConfigAuthenticatorOK) GetPayload ¶

func (o *FindConfigAuthenticatorOK) GetPayload() string

type FindConfigAuthenticatorParams ¶

type FindConfigAuthenticatorParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAuthenticatorParams contains all the parameters to send to the API endpoint for the find config authenticator operation typically these are written to a http.Request

func NewFindConfigAuthenticatorParams ¶

func NewFindConfigAuthenticatorParams() *FindConfigAuthenticatorParams

NewFindConfigAuthenticatorParams creates a new FindConfigAuthenticatorParams object with the default values initialized.

func NewFindConfigAuthenticatorParamsWithContext ¶

func NewFindConfigAuthenticatorParamsWithContext(ctx context.Context) *FindConfigAuthenticatorParams

NewFindConfigAuthenticatorParamsWithContext creates a new FindConfigAuthenticatorParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAuthenticatorParamsWithHTTPClient ¶

func NewFindConfigAuthenticatorParamsWithHTTPClient(client *http.Client) *FindConfigAuthenticatorParams

NewFindConfigAuthenticatorParamsWithHTTPClient creates a new FindConfigAuthenticatorParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAuthenticatorParamsWithTimeout ¶

func NewFindConfigAuthenticatorParamsWithTimeout(timeout time.Duration) *FindConfigAuthenticatorParams

NewFindConfigAuthenticatorParamsWithTimeout creates a new FindConfigAuthenticatorParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAuthenticatorParams) SetContext ¶

func (o *FindConfigAuthenticatorParams) SetContext(ctx context.Context)

SetContext adds the context to the find config authenticator params

func (*FindConfigAuthenticatorParams) SetHTTPClient ¶

func (o *FindConfigAuthenticatorParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config authenticator params

func (*FindConfigAuthenticatorParams) SetTimeout ¶

func (o *FindConfigAuthenticatorParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config authenticator params

func (*FindConfigAuthenticatorParams) WithContext ¶

WithContext adds the context to the find config authenticator params

func (*FindConfigAuthenticatorParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config authenticator params

func (*FindConfigAuthenticatorParams) WithTimeout ¶

WithTimeout adds the timeout to the find config authenticator params

func (*FindConfigAuthenticatorParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAuthenticatorReader ¶

type FindConfigAuthenticatorReader struct {
	// contains filtered or unexported fields
}

FindConfigAuthenticatorReader is a Reader for the FindConfigAuthenticator structure.

func (*FindConfigAuthenticatorReader) ReadResponse ¶

func (o *FindConfigAuthenticatorReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAuthorizerDefault ¶

type FindConfigAuthorizerDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAuthorizerDefault handles this case with default header values.

unexpected error

func NewFindConfigAuthorizerDefault ¶

func NewFindConfigAuthorizerDefault(code int) *FindConfigAuthorizerDefault

NewFindConfigAuthorizerDefault creates a FindConfigAuthorizerDefault with default headers values

func (*FindConfigAuthorizerDefault) Code ¶

func (o *FindConfigAuthorizerDefault) Code() int

Code gets the status code for the find config authorizer default response

func (*FindConfigAuthorizerDefault) Error ¶

func (*FindConfigAuthorizerDefault) GetPayload ¶

type FindConfigAuthorizerOK ¶

type FindConfigAuthorizerOK struct {
	Payload string
}

FindConfigAuthorizerOK handles this case with default header values.

Config value

func NewFindConfigAuthorizerOK ¶

func NewFindConfigAuthorizerOK() *FindConfigAuthorizerOK

NewFindConfigAuthorizerOK creates a FindConfigAuthorizerOK with default headers values

func (*FindConfigAuthorizerOK) GetPayload ¶

func (o *FindConfigAuthorizerOK) GetPayload() string

type FindConfigAuthorizerParams ¶

type FindConfigAuthorizerParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAuthorizerParams contains all the parameters to send to the API endpoint for the find config authorizer operation typically these are written to a http.Request

func NewFindConfigAuthorizerParams ¶

func NewFindConfigAuthorizerParams() *FindConfigAuthorizerParams

NewFindConfigAuthorizerParams creates a new FindConfigAuthorizerParams object with the default values initialized.

func NewFindConfigAuthorizerParamsWithContext ¶

func NewFindConfigAuthorizerParamsWithContext(ctx context.Context) *FindConfigAuthorizerParams

NewFindConfigAuthorizerParamsWithContext creates a new FindConfigAuthorizerParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAuthorizerParamsWithHTTPClient ¶

func NewFindConfigAuthorizerParamsWithHTTPClient(client *http.Client) *FindConfigAuthorizerParams

NewFindConfigAuthorizerParamsWithHTTPClient creates a new FindConfigAuthorizerParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAuthorizerParamsWithTimeout ¶

func NewFindConfigAuthorizerParamsWithTimeout(timeout time.Duration) *FindConfigAuthorizerParams

NewFindConfigAuthorizerParamsWithTimeout creates a new FindConfigAuthorizerParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAuthorizerParams) SetContext ¶

func (o *FindConfigAuthorizerParams) SetContext(ctx context.Context)

SetContext adds the context to the find config authorizer params

func (*FindConfigAuthorizerParams) SetHTTPClient ¶

func (o *FindConfigAuthorizerParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config authorizer params

func (*FindConfigAuthorizerParams) SetTimeout ¶

func (o *FindConfigAuthorizerParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config authorizer params

func (*FindConfigAuthorizerParams) WithContext ¶

WithContext adds the context to the find config authorizer params

func (*FindConfigAuthorizerParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config authorizer params

func (*FindConfigAuthorizerParams) WithTimeout ¶

WithTimeout adds the timeout to the find config authorizer params

func (*FindConfigAuthorizerParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAuthorizerReader ¶

type FindConfigAuthorizerReader struct {
	// contains filtered or unexported fields
}

FindConfigAuthorizerReader is a Reader for the FindConfigAuthorizer structure.

func (*FindConfigAuthorizerReader) ReadResponse ¶

func (o *FindConfigAuthorizerReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAutoAdjustFlushQuotaDefault ¶

type FindConfigAutoAdjustFlushQuotaDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAutoAdjustFlushQuotaDefault handles this case with default header values.

unexpected error

func NewFindConfigAutoAdjustFlushQuotaDefault ¶

func NewFindConfigAutoAdjustFlushQuotaDefault(code int) *FindConfigAutoAdjustFlushQuotaDefault

NewFindConfigAutoAdjustFlushQuotaDefault creates a FindConfigAutoAdjustFlushQuotaDefault with default headers values

func (*FindConfigAutoAdjustFlushQuotaDefault) Code ¶

Code gets the status code for the find config auto adjust flush quota default response

func (*FindConfigAutoAdjustFlushQuotaDefault) Error ¶

func (*FindConfigAutoAdjustFlushQuotaDefault) GetPayload ¶

type FindConfigAutoAdjustFlushQuotaOK ¶

type FindConfigAutoAdjustFlushQuotaOK struct {
	Payload bool
}

FindConfigAutoAdjustFlushQuotaOK handles this case with default header values.

Config value

func NewFindConfigAutoAdjustFlushQuotaOK ¶

func NewFindConfigAutoAdjustFlushQuotaOK() *FindConfigAutoAdjustFlushQuotaOK

NewFindConfigAutoAdjustFlushQuotaOK creates a FindConfigAutoAdjustFlushQuotaOK with default headers values

func (*FindConfigAutoAdjustFlushQuotaOK) GetPayload ¶

func (o *FindConfigAutoAdjustFlushQuotaOK) GetPayload() bool

type FindConfigAutoAdjustFlushQuotaParams ¶

type FindConfigAutoAdjustFlushQuotaParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAutoAdjustFlushQuotaParams contains all the parameters to send to the API endpoint for the find config auto adjust flush quota operation typically these are written to a http.Request

func NewFindConfigAutoAdjustFlushQuotaParams ¶

func NewFindConfigAutoAdjustFlushQuotaParams() *FindConfigAutoAdjustFlushQuotaParams

NewFindConfigAutoAdjustFlushQuotaParams creates a new FindConfigAutoAdjustFlushQuotaParams object with the default values initialized.

func NewFindConfigAutoAdjustFlushQuotaParamsWithContext ¶

func NewFindConfigAutoAdjustFlushQuotaParamsWithContext(ctx context.Context) *FindConfigAutoAdjustFlushQuotaParams

NewFindConfigAutoAdjustFlushQuotaParamsWithContext creates a new FindConfigAutoAdjustFlushQuotaParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAutoAdjustFlushQuotaParamsWithHTTPClient ¶

func NewFindConfigAutoAdjustFlushQuotaParamsWithHTTPClient(client *http.Client) *FindConfigAutoAdjustFlushQuotaParams

NewFindConfigAutoAdjustFlushQuotaParamsWithHTTPClient creates a new FindConfigAutoAdjustFlushQuotaParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAutoAdjustFlushQuotaParamsWithTimeout ¶

func NewFindConfigAutoAdjustFlushQuotaParamsWithTimeout(timeout time.Duration) *FindConfigAutoAdjustFlushQuotaParams

NewFindConfigAutoAdjustFlushQuotaParamsWithTimeout creates a new FindConfigAutoAdjustFlushQuotaParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAutoAdjustFlushQuotaParams) SetContext ¶

SetContext adds the context to the find config auto adjust flush quota params

func (*FindConfigAutoAdjustFlushQuotaParams) SetHTTPClient ¶

func (o *FindConfigAutoAdjustFlushQuotaParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config auto adjust flush quota params

func (*FindConfigAutoAdjustFlushQuotaParams) SetTimeout ¶

func (o *FindConfigAutoAdjustFlushQuotaParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config auto adjust flush quota params

func (*FindConfigAutoAdjustFlushQuotaParams) WithContext ¶

WithContext adds the context to the find config auto adjust flush quota params

func (*FindConfigAutoAdjustFlushQuotaParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config auto adjust flush quota params

func (*FindConfigAutoAdjustFlushQuotaParams) WithTimeout ¶

WithTimeout adds the timeout to the find config auto adjust flush quota params

func (*FindConfigAutoAdjustFlushQuotaParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAutoAdjustFlushQuotaReader ¶

type FindConfigAutoAdjustFlushQuotaReader struct {
	// contains filtered or unexported fields
}

FindConfigAutoAdjustFlushQuotaReader is a Reader for the FindConfigAutoAdjustFlushQuota structure.

func (*FindConfigAutoAdjustFlushQuotaReader) ReadResponse ¶

func (o *FindConfigAutoAdjustFlushQuotaReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAutoBootstrapDefault ¶

type FindConfigAutoBootstrapDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAutoBootstrapDefault handles this case with default header values.

unexpected error

func NewFindConfigAutoBootstrapDefault ¶

func NewFindConfigAutoBootstrapDefault(code int) *FindConfigAutoBootstrapDefault

NewFindConfigAutoBootstrapDefault creates a FindConfigAutoBootstrapDefault with default headers values

func (*FindConfigAutoBootstrapDefault) Code ¶

Code gets the status code for the find config auto bootstrap default response

func (*FindConfigAutoBootstrapDefault) Error ¶

func (*FindConfigAutoBootstrapDefault) GetPayload ¶

type FindConfigAutoBootstrapOK ¶

type FindConfigAutoBootstrapOK struct {
	Payload bool
}

FindConfigAutoBootstrapOK handles this case with default header values.

Config value

func NewFindConfigAutoBootstrapOK ¶

func NewFindConfigAutoBootstrapOK() *FindConfigAutoBootstrapOK

NewFindConfigAutoBootstrapOK creates a FindConfigAutoBootstrapOK with default headers values

func (*FindConfigAutoBootstrapOK) GetPayload ¶

func (o *FindConfigAutoBootstrapOK) GetPayload() bool

type FindConfigAutoBootstrapParams ¶

type FindConfigAutoBootstrapParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAutoBootstrapParams contains all the parameters to send to the API endpoint for the find config auto bootstrap operation typically these are written to a http.Request

func NewFindConfigAutoBootstrapParams ¶

func NewFindConfigAutoBootstrapParams() *FindConfigAutoBootstrapParams

NewFindConfigAutoBootstrapParams creates a new FindConfigAutoBootstrapParams object with the default values initialized.

func NewFindConfigAutoBootstrapParamsWithContext ¶

func NewFindConfigAutoBootstrapParamsWithContext(ctx context.Context) *FindConfigAutoBootstrapParams

NewFindConfigAutoBootstrapParamsWithContext creates a new FindConfigAutoBootstrapParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAutoBootstrapParamsWithHTTPClient ¶

func NewFindConfigAutoBootstrapParamsWithHTTPClient(client *http.Client) *FindConfigAutoBootstrapParams

NewFindConfigAutoBootstrapParamsWithHTTPClient creates a new FindConfigAutoBootstrapParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAutoBootstrapParamsWithTimeout ¶

func NewFindConfigAutoBootstrapParamsWithTimeout(timeout time.Duration) *FindConfigAutoBootstrapParams

NewFindConfigAutoBootstrapParamsWithTimeout creates a new FindConfigAutoBootstrapParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAutoBootstrapParams) SetContext ¶

func (o *FindConfigAutoBootstrapParams) SetContext(ctx context.Context)

SetContext adds the context to the find config auto bootstrap params

func (*FindConfigAutoBootstrapParams) SetHTTPClient ¶

func (o *FindConfigAutoBootstrapParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config auto bootstrap params

func (*FindConfigAutoBootstrapParams) SetTimeout ¶

func (o *FindConfigAutoBootstrapParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config auto bootstrap params

func (*FindConfigAutoBootstrapParams) WithContext ¶

WithContext adds the context to the find config auto bootstrap params

func (*FindConfigAutoBootstrapParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config auto bootstrap params

func (*FindConfigAutoBootstrapParams) WithTimeout ¶

WithTimeout adds the timeout to the find config auto bootstrap params

func (*FindConfigAutoBootstrapParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAutoBootstrapReader ¶

type FindConfigAutoBootstrapReader struct {
	// contains filtered or unexported fields
}

FindConfigAutoBootstrapReader is a Reader for the FindConfigAutoBootstrap structure.

func (*FindConfigAutoBootstrapReader) ReadResponse ¶

func (o *FindConfigAutoBootstrapReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigAutoSnapshotDefault ¶

type FindConfigAutoSnapshotDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigAutoSnapshotDefault handles this case with default header values.

unexpected error

func NewFindConfigAutoSnapshotDefault ¶

func NewFindConfigAutoSnapshotDefault(code int) *FindConfigAutoSnapshotDefault

NewFindConfigAutoSnapshotDefault creates a FindConfigAutoSnapshotDefault with default headers values

func (*FindConfigAutoSnapshotDefault) Code ¶

Code gets the status code for the find config auto snapshot default response

func (*FindConfigAutoSnapshotDefault) Error ¶

func (*FindConfigAutoSnapshotDefault) GetPayload ¶

type FindConfigAutoSnapshotOK ¶

type FindConfigAutoSnapshotOK struct {
	Payload bool
}

FindConfigAutoSnapshotOK handles this case with default header values.

Config value

func NewFindConfigAutoSnapshotOK ¶

func NewFindConfigAutoSnapshotOK() *FindConfigAutoSnapshotOK

NewFindConfigAutoSnapshotOK creates a FindConfigAutoSnapshotOK with default headers values

func (*FindConfigAutoSnapshotOK) GetPayload ¶

func (o *FindConfigAutoSnapshotOK) GetPayload() bool

type FindConfigAutoSnapshotParams ¶

type FindConfigAutoSnapshotParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigAutoSnapshotParams contains all the parameters to send to the API endpoint for the find config auto snapshot operation typically these are written to a http.Request

func NewFindConfigAutoSnapshotParams ¶

func NewFindConfigAutoSnapshotParams() *FindConfigAutoSnapshotParams

NewFindConfigAutoSnapshotParams creates a new FindConfigAutoSnapshotParams object with the default values initialized.

func NewFindConfigAutoSnapshotParamsWithContext ¶

func NewFindConfigAutoSnapshotParamsWithContext(ctx context.Context) *FindConfigAutoSnapshotParams

NewFindConfigAutoSnapshotParamsWithContext creates a new FindConfigAutoSnapshotParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigAutoSnapshotParamsWithHTTPClient ¶

func NewFindConfigAutoSnapshotParamsWithHTTPClient(client *http.Client) *FindConfigAutoSnapshotParams

NewFindConfigAutoSnapshotParamsWithHTTPClient creates a new FindConfigAutoSnapshotParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigAutoSnapshotParamsWithTimeout ¶

func NewFindConfigAutoSnapshotParamsWithTimeout(timeout time.Duration) *FindConfigAutoSnapshotParams

NewFindConfigAutoSnapshotParamsWithTimeout creates a new FindConfigAutoSnapshotParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigAutoSnapshotParams) SetContext ¶

func (o *FindConfigAutoSnapshotParams) SetContext(ctx context.Context)

SetContext adds the context to the find config auto snapshot params

func (*FindConfigAutoSnapshotParams) SetHTTPClient ¶

func (o *FindConfigAutoSnapshotParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config auto snapshot params

func (*FindConfigAutoSnapshotParams) SetTimeout ¶

func (o *FindConfigAutoSnapshotParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config auto snapshot params

func (*FindConfigAutoSnapshotParams) WithContext ¶

WithContext adds the context to the find config auto snapshot params

func (*FindConfigAutoSnapshotParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config auto snapshot params

func (*FindConfigAutoSnapshotParams) WithTimeout ¶

WithTimeout adds the timeout to the find config auto snapshot params

func (*FindConfigAutoSnapshotParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigAutoSnapshotReader ¶

type FindConfigAutoSnapshotReader struct {
	// contains filtered or unexported fields
}

FindConfigAutoSnapshotReader is a Reader for the FindConfigAutoSnapshot structure.

func (*FindConfigAutoSnapshotReader) ReadResponse ¶

func (o *FindConfigAutoSnapshotReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigBackgroundWriterSchedulingQuotaDefault ¶

type FindConfigBackgroundWriterSchedulingQuotaDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigBackgroundWriterSchedulingQuotaDefault handles this case with default header values.

unexpected error

func NewFindConfigBackgroundWriterSchedulingQuotaDefault ¶

func NewFindConfigBackgroundWriterSchedulingQuotaDefault(code int) *FindConfigBackgroundWriterSchedulingQuotaDefault

NewFindConfigBackgroundWriterSchedulingQuotaDefault creates a FindConfigBackgroundWriterSchedulingQuotaDefault with default headers values

func (*FindConfigBackgroundWriterSchedulingQuotaDefault) Code ¶

Code gets the status code for the find config background writer scheduling quota default response

func (*FindConfigBackgroundWriterSchedulingQuotaDefault) Error ¶

func (*FindConfigBackgroundWriterSchedulingQuotaDefault) GetPayload ¶

type FindConfigBackgroundWriterSchedulingQuotaOK ¶

type FindConfigBackgroundWriterSchedulingQuotaOK struct {
	Payload float64
}

FindConfigBackgroundWriterSchedulingQuotaOK handles this case with default header values.

Config value

func NewFindConfigBackgroundWriterSchedulingQuotaOK ¶

func NewFindConfigBackgroundWriterSchedulingQuotaOK() *FindConfigBackgroundWriterSchedulingQuotaOK

NewFindConfigBackgroundWriterSchedulingQuotaOK creates a FindConfigBackgroundWriterSchedulingQuotaOK with default headers values

func (*FindConfigBackgroundWriterSchedulingQuotaOK) GetPayload ¶

type FindConfigBackgroundWriterSchedulingQuotaParams ¶

type FindConfigBackgroundWriterSchedulingQuotaParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigBackgroundWriterSchedulingQuotaParams contains all the parameters to send to the API endpoint for the find config background writer scheduling quota operation typically these are written to a http.Request

func NewFindConfigBackgroundWriterSchedulingQuotaParams ¶

func NewFindConfigBackgroundWriterSchedulingQuotaParams() *FindConfigBackgroundWriterSchedulingQuotaParams

NewFindConfigBackgroundWriterSchedulingQuotaParams creates a new FindConfigBackgroundWriterSchedulingQuotaParams object with the default values initialized.

func NewFindConfigBackgroundWriterSchedulingQuotaParamsWithContext ¶

func NewFindConfigBackgroundWriterSchedulingQuotaParamsWithContext(ctx context.Context) *FindConfigBackgroundWriterSchedulingQuotaParams

NewFindConfigBackgroundWriterSchedulingQuotaParamsWithContext creates a new FindConfigBackgroundWriterSchedulingQuotaParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigBackgroundWriterSchedulingQuotaParamsWithHTTPClient ¶

func NewFindConfigBackgroundWriterSchedulingQuotaParamsWithHTTPClient(client *http.Client) *FindConfigBackgroundWriterSchedulingQuotaParams

NewFindConfigBackgroundWriterSchedulingQuotaParamsWithHTTPClient creates a new FindConfigBackgroundWriterSchedulingQuotaParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigBackgroundWriterSchedulingQuotaParamsWithTimeout ¶

func NewFindConfigBackgroundWriterSchedulingQuotaParamsWithTimeout(timeout time.Duration) *FindConfigBackgroundWriterSchedulingQuotaParams

NewFindConfigBackgroundWriterSchedulingQuotaParamsWithTimeout creates a new FindConfigBackgroundWriterSchedulingQuotaParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigBackgroundWriterSchedulingQuotaParams) SetContext ¶

SetContext adds the context to the find config background writer scheduling quota params

func (*FindConfigBackgroundWriterSchedulingQuotaParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config background writer scheduling quota params

func (*FindConfigBackgroundWriterSchedulingQuotaParams) SetTimeout ¶

SetTimeout adds the timeout to the find config background writer scheduling quota params

func (*FindConfigBackgroundWriterSchedulingQuotaParams) WithContext ¶

WithContext adds the context to the find config background writer scheduling quota params

func (*FindConfigBackgroundWriterSchedulingQuotaParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config background writer scheduling quota params

func (*FindConfigBackgroundWriterSchedulingQuotaParams) WithTimeout ¶

WithTimeout adds the timeout to the find config background writer scheduling quota params

func (*FindConfigBackgroundWriterSchedulingQuotaParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigBackgroundWriterSchedulingQuotaReader ¶

type FindConfigBackgroundWriterSchedulingQuotaReader struct {
	// contains filtered or unexported fields
}

FindConfigBackgroundWriterSchedulingQuotaReader is a Reader for the FindConfigBackgroundWriterSchedulingQuota structure.

func (*FindConfigBackgroundWriterSchedulingQuotaReader) ReadResponse ¶

func (o *FindConfigBackgroundWriterSchedulingQuotaReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigBatchSizeFailThresholdInKbDefault ¶

type FindConfigBatchSizeFailThresholdInKbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigBatchSizeFailThresholdInKbDefault handles this case with default header values.

unexpected error

func NewFindConfigBatchSizeFailThresholdInKbDefault ¶

func NewFindConfigBatchSizeFailThresholdInKbDefault(code int) *FindConfigBatchSizeFailThresholdInKbDefault

NewFindConfigBatchSizeFailThresholdInKbDefault creates a FindConfigBatchSizeFailThresholdInKbDefault with default headers values

func (*FindConfigBatchSizeFailThresholdInKbDefault) Code ¶

Code gets the status code for the find config batch size fail threshold in kb default response

func (*FindConfigBatchSizeFailThresholdInKbDefault) Error ¶

func (*FindConfigBatchSizeFailThresholdInKbDefault) GetPayload ¶

type FindConfigBatchSizeFailThresholdInKbOK ¶

type FindConfigBatchSizeFailThresholdInKbOK struct {
	Payload int64
}

FindConfigBatchSizeFailThresholdInKbOK handles this case with default header values.

Config value

func NewFindConfigBatchSizeFailThresholdInKbOK ¶

func NewFindConfigBatchSizeFailThresholdInKbOK() *FindConfigBatchSizeFailThresholdInKbOK

NewFindConfigBatchSizeFailThresholdInKbOK creates a FindConfigBatchSizeFailThresholdInKbOK with default headers values

func (*FindConfigBatchSizeFailThresholdInKbOK) GetPayload ¶

type FindConfigBatchSizeFailThresholdInKbParams ¶

type FindConfigBatchSizeFailThresholdInKbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigBatchSizeFailThresholdInKbParams contains all the parameters to send to the API endpoint for the find config batch size fail threshold in kb operation typically these are written to a http.Request

func NewFindConfigBatchSizeFailThresholdInKbParams ¶

func NewFindConfigBatchSizeFailThresholdInKbParams() *FindConfigBatchSizeFailThresholdInKbParams

NewFindConfigBatchSizeFailThresholdInKbParams creates a new FindConfigBatchSizeFailThresholdInKbParams object with the default values initialized.

func NewFindConfigBatchSizeFailThresholdInKbParamsWithContext ¶

func NewFindConfigBatchSizeFailThresholdInKbParamsWithContext(ctx context.Context) *FindConfigBatchSizeFailThresholdInKbParams

NewFindConfigBatchSizeFailThresholdInKbParamsWithContext creates a new FindConfigBatchSizeFailThresholdInKbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigBatchSizeFailThresholdInKbParamsWithHTTPClient ¶

func NewFindConfigBatchSizeFailThresholdInKbParamsWithHTTPClient(client *http.Client) *FindConfigBatchSizeFailThresholdInKbParams

NewFindConfigBatchSizeFailThresholdInKbParamsWithHTTPClient creates a new FindConfigBatchSizeFailThresholdInKbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigBatchSizeFailThresholdInKbParamsWithTimeout ¶

func NewFindConfigBatchSizeFailThresholdInKbParamsWithTimeout(timeout time.Duration) *FindConfigBatchSizeFailThresholdInKbParams

NewFindConfigBatchSizeFailThresholdInKbParamsWithTimeout creates a new FindConfigBatchSizeFailThresholdInKbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigBatchSizeFailThresholdInKbParams) SetContext ¶

SetContext adds the context to the find config batch size fail threshold in kb params

func (*FindConfigBatchSizeFailThresholdInKbParams) SetHTTPClient ¶

func (o *FindConfigBatchSizeFailThresholdInKbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config batch size fail threshold in kb params

func (*FindConfigBatchSizeFailThresholdInKbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config batch size fail threshold in kb params

func (*FindConfigBatchSizeFailThresholdInKbParams) WithContext ¶

WithContext adds the context to the find config batch size fail threshold in kb params

func (*FindConfigBatchSizeFailThresholdInKbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config batch size fail threshold in kb params

func (*FindConfigBatchSizeFailThresholdInKbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config batch size fail threshold in kb params

func (*FindConfigBatchSizeFailThresholdInKbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigBatchSizeFailThresholdInKbReader ¶

type FindConfigBatchSizeFailThresholdInKbReader struct {
	// contains filtered or unexported fields
}

FindConfigBatchSizeFailThresholdInKbReader is a Reader for the FindConfigBatchSizeFailThresholdInKb structure.

func (*FindConfigBatchSizeFailThresholdInKbReader) ReadResponse ¶

func (o *FindConfigBatchSizeFailThresholdInKbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigBatchSizeWarnThresholdInKbDefault ¶

type FindConfigBatchSizeWarnThresholdInKbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigBatchSizeWarnThresholdInKbDefault handles this case with default header values.

unexpected error

func NewFindConfigBatchSizeWarnThresholdInKbDefault ¶

func NewFindConfigBatchSizeWarnThresholdInKbDefault(code int) *FindConfigBatchSizeWarnThresholdInKbDefault

NewFindConfigBatchSizeWarnThresholdInKbDefault creates a FindConfigBatchSizeWarnThresholdInKbDefault with default headers values

func (*FindConfigBatchSizeWarnThresholdInKbDefault) Code ¶

Code gets the status code for the find config batch size warn threshold in kb default response

func (*FindConfigBatchSizeWarnThresholdInKbDefault) Error ¶

func (*FindConfigBatchSizeWarnThresholdInKbDefault) GetPayload ¶

type FindConfigBatchSizeWarnThresholdInKbOK ¶

type FindConfigBatchSizeWarnThresholdInKbOK struct {
	Payload int64
}

FindConfigBatchSizeWarnThresholdInKbOK handles this case with default header values.

Config value

func NewFindConfigBatchSizeWarnThresholdInKbOK ¶

func NewFindConfigBatchSizeWarnThresholdInKbOK() *FindConfigBatchSizeWarnThresholdInKbOK

NewFindConfigBatchSizeWarnThresholdInKbOK creates a FindConfigBatchSizeWarnThresholdInKbOK with default headers values

func (*FindConfigBatchSizeWarnThresholdInKbOK) GetPayload ¶

type FindConfigBatchSizeWarnThresholdInKbParams ¶

type FindConfigBatchSizeWarnThresholdInKbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigBatchSizeWarnThresholdInKbParams contains all the parameters to send to the API endpoint for the find config batch size warn threshold in kb operation typically these are written to a http.Request

func NewFindConfigBatchSizeWarnThresholdInKbParams ¶

func NewFindConfigBatchSizeWarnThresholdInKbParams() *FindConfigBatchSizeWarnThresholdInKbParams

NewFindConfigBatchSizeWarnThresholdInKbParams creates a new FindConfigBatchSizeWarnThresholdInKbParams object with the default values initialized.

func NewFindConfigBatchSizeWarnThresholdInKbParamsWithContext ¶

func NewFindConfigBatchSizeWarnThresholdInKbParamsWithContext(ctx context.Context) *FindConfigBatchSizeWarnThresholdInKbParams

NewFindConfigBatchSizeWarnThresholdInKbParamsWithContext creates a new FindConfigBatchSizeWarnThresholdInKbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigBatchSizeWarnThresholdInKbParamsWithHTTPClient ¶

func NewFindConfigBatchSizeWarnThresholdInKbParamsWithHTTPClient(client *http.Client) *FindConfigBatchSizeWarnThresholdInKbParams

NewFindConfigBatchSizeWarnThresholdInKbParamsWithHTTPClient creates a new FindConfigBatchSizeWarnThresholdInKbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigBatchSizeWarnThresholdInKbParamsWithTimeout ¶

func NewFindConfigBatchSizeWarnThresholdInKbParamsWithTimeout(timeout time.Duration) *FindConfigBatchSizeWarnThresholdInKbParams

NewFindConfigBatchSizeWarnThresholdInKbParamsWithTimeout creates a new FindConfigBatchSizeWarnThresholdInKbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigBatchSizeWarnThresholdInKbParams) SetContext ¶

SetContext adds the context to the find config batch size warn threshold in kb params

func (*FindConfigBatchSizeWarnThresholdInKbParams) SetHTTPClient ¶

func (o *FindConfigBatchSizeWarnThresholdInKbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config batch size warn threshold in kb params

func (*FindConfigBatchSizeWarnThresholdInKbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config batch size warn threshold in kb params

func (*FindConfigBatchSizeWarnThresholdInKbParams) WithContext ¶

WithContext adds the context to the find config batch size warn threshold in kb params

func (*FindConfigBatchSizeWarnThresholdInKbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config batch size warn threshold in kb params

func (*FindConfigBatchSizeWarnThresholdInKbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config batch size warn threshold in kb params

func (*FindConfigBatchSizeWarnThresholdInKbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigBatchSizeWarnThresholdInKbReader ¶

type FindConfigBatchSizeWarnThresholdInKbReader struct {
	// contains filtered or unexported fields
}

FindConfigBatchSizeWarnThresholdInKbReader is a Reader for the FindConfigBatchSizeWarnThresholdInKb structure.

func (*FindConfigBatchSizeWarnThresholdInKbReader) ReadResponse ¶

func (o *FindConfigBatchSizeWarnThresholdInKbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigBatchlogReplayThrottleInKbDefault ¶

type FindConfigBatchlogReplayThrottleInKbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigBatchlogReplayThrottleInKbDefault handles this case with default header values.

unexpected error

func NewFindConfigBatchlogReplayThrottleInKbDefault ¶

func NewFindConfigBatchlogReplayThrottleInKbDefault(code int) *FindConfigBatchlogReplayThrottleInKbDefault

NewFindConfigBatchlogReplayThrottleInKbDefault creates a FindConfigBatchlogReplayThrottleInKbDefault with default headers values

func (*FindConfigBatchlogReplayThrottleInKbDefault) Code ¶

Code gets the status code for the find config batchlog replay throttle in kb default response

func (*FindConfigBatchlogReplayThrottleInKbDefault) Error ¶

func (*FindConfigBatchlogReplayThrottleInKbDefault) GetPayload ¶

type FindConfigBatchlogReplayThrottleInKbOK ¶

type FindConfigBatchlogReplayThrottleInKbOK struct {
	Payload int64
}

FindConfigBatchlogReplayThrottleInKbOK handles this case with default header values.

Config value

func NewFindConfigBatchlogReplayThrottleInKbOK ¶

func NewFindConfigBatchlogReplayThrottleInKbOK() *FindConfigBatchlogReplayThrottleInKbOK

NewFindConfigBatchlogReplayThrottleInKbOK creates a FindConfigBatchlogReplayThrottleInKbOK with default headers values

func (*FindConfigBatchlogReplayThrottleInKbOK) GetPayload ¶

type FindConfigBatchlogReplayThrottleInKbParams ¶

type FindConfigBatchlogReplayThrottleInKbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigBatchlogReplayThrottleInKbParams contains all the parameters to send to the API endpoint for the find config batchlog replay throttle in kb operation typically these are written to a http.Request

func NewFindConfigBatchlogReplayThrottleInKbParams ¶

func NewFindConfigBatchlogReplayThrottleInKbParams() *FindConfigBatchlogReplayThrottleInKbParams

NewFindConfigBatchlogReplayThrottleInKbParams creates a new FindConfigBatchlogReplayThrottleInKbParams object with the default values initialized.

func NewFindConfigBatchlogReplayThrottleInKbParamsWithContext ¶

func NewFindConfigBatchlogReplayThrottleInKbParamsWithContext(ctx context.Context) *FindConfigBatchlogReplayThrottleInKbParams

NewFindConfigBatchlogReplayThrottleInKbParamsWithContext creates a new FindConfigBatchlogReplayThrottleInKbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigBatchlogReplayThrottleInKbParamsWithHTTPClient ¶

func NewFindConfigBatchlogReplayThrottleInKbParamsWithHTTPClient(client *http.Client) *FindConfigBatchlogReplayThrottleInKbParams

NewFindConfigBatchlogReplayThrottleInKbParamsWithHTTPClient creates a new FindConfigBatchlogReplayThrottleInKbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigBatchlogReplayThrottleInKbParamsWithTimeout ¶

func NewFindConfigBatchlogReplayThrottleInKbParamsWithTimeout(timeout time.Duration) *FindConfigBatchlogReplayThrottleInKbParams

NewFindConfigBatchlogReplayThrottleInKbParamsWithTimeout creates a new FindConfigBatchlogReplayThrottleInKbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigBatchlogReplayThrottleInKbParams) SetContext ¶

SetContext adds the context to the find config batchlog replay throttle in kb params

func (*FindConfigBatchlogReplayThrottleInKbParams) SetHTTPClient ¶

func (o *FindConfigBatchlogReplayThrottleInKbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config batchlog replay throttle in kb params

func (*FindConfigBatchlogReplayThrottleInKbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config batchlog replay throttle in kb params

func (*FindConfigBatchlogReplayThrottleInKbParams) WithContext ¶

WithContext adds the context to the find config batchlog replay throttle in kb params

func (*FindConfigBatchlogReplayThrottleInKbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config batchlog replay throttle in kb params

func (*FindConfigBatchlogReplayThrottleInKbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config batchlog replay throttle in kb params

func (*FindConfigBatchlogReplayThrottleInKbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigBatchlogReplayThrottleInKbReader ¶

type FindConfigBatchlogReplayThrottleInKbReader struct {
	// contains filtered or unexported fields
}

FindConfigBatchlogReplayThrottleInKbReader is a Reader for the FindConfigBatchlogReplayThrottleInKb structure.

func (*FindConfigBatchlogReplayThrottleInKbReader) ReadResponse ¶

func (o *FindConfigBatchlogReplayThrottleInKbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigBroadcastAddressDefault ¶

type FindConfigBroadcastAddressDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigBroadcastAddressDefault handles this case with default header values.

unexpected error

func NewFindConfigBroadcastAddressDefault ¶

func NewFindConfigBroadcastAddressDefault(code int) *FindConfigBroadcastAddressDefault

NewFindConfigBroadcastAddressDefault creates a FindConfigBroadcastAddressDefault with default headers values

func (*FindConfigBroadcastAddressDefault) Code ¶

Code gets the status code for the find config broadcast address default response

func (*FindConfigBroadcastAddressDefault) Error ¶

func (*FindConfigBroadcastAddressDefault) GetPayload ¶

type FindConfigBroadcastAddressOK ¶

type FindConfigBroadcastAddressOK struct {
	Payload string
}

FindConfigBroadcastAddressOK handles this case with default header values.

Config value

func NewFindConfigBroadcastAddressOK ¶

func NewFindConfigBroadcastAddressOK() *FindConfigBroadcastAddressOK

NewFindConfigBroadcastAddressOK creates a FindConfigBroadcastAddressOK with default headers values

func (*FindConfigBroadcastAddressOK) GetPayload ¶

func (o *FindConfigBroadcastAddressOK) GetPayload() string

type FindConfigBroadcastAddressParams ¶

type FindConfigBroadcastAddressParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigBroadcastAddressParams contains all the parameters to send to the API endpoint for the find config broadcast address operation typically these are written to a http.Request

func NewFindConfigBroadcastAddressParams ¶

func NewFindConfigBroadcastAddressParams() *FindConfigBroadcastAddressParams

NewFindConfigBroadcastAddressParams creates a new FindConfigBroadcastAddressParams object with the default values initialized.

func NewFindConfigBroadcastAddressParamsWithContext ¶

func NewFindConfigBroadcastAddressParamsWithContext(ctx context.Context) *FindConfigBroadcastAddressParams

NewFindConfigBroadcastAddressParamsWithContext creates a new FindConfigBroadcastAddressParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigBroadcastAddressParamsWithHTTPClient ¶

func NewFindConfigBroadcastAddressParamsWithHTTPClient(client *http.Client) *FindConfigBroadcastAddressParams

NewFindConfigBroadcastAddressParamsWithHTTPClient creates a new FindConfigBroadcastAddressParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigBroadcastAddressParamsWithTimeout ¶

func NewFindConfigBroadcastAddressParamsWithTimeout(timeout time.Duration) *FindConfigBroadcastAddressParams

NewFindConfigBroadcastAddressParamsWithTimeout creates a new FindConfigBroadcastAddressParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigBroadcastAddressParams) SetContext ¶

SetContext adds the context to the find config broadcast address params

func (*FindConfigBroadcastAddressParams) SetHTTPClient ¶

func (o *FindConfigBroadcastAddressParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config broadcast address params

func (*FindConfigBroadcastAddressParams) SetTimeout ¶

func (o *FindConfigBroadcastAddressParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config broadcast address params

func (*FindConfigBroadcastAddressParams) WithContext ¶

WithContext adds the context to the find config broadcast address params

func (*FindConfigBroadcastAddressParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config broadcast address params

func (*FindConfigBroadcastAddressParams) WithTimeout ¶

WithTimeout adds the timeout to the find config broadcast address params

func (*FindConfigBroadcastAddressParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigBroadcastAddressReader ¶

type FindConfigBroadcastAddressReader struct {
	// contains filtered or unexported fields
}

FindConfigBroadcastAddressReader is a Reader for the FindConfigBroadcastAddress structure.

func (*FindConfigBroadcastAddressReader) ReadResponse ¶

func (o *FindConfigBroadcastAddressReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigBroadcastRPCAddressDefault ¶

type FindConfigBroadcastRPCAddressDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigBroadcastRPCAddressDefault handles this case with default header values.

unexpected error

func NewFindConfigBroadcastRPCAddressDefault ¶

func NewFindConfigBroadcastRPCAddressDefault(code int) *FindConfigBroadcastRPCAddressDefault

NewFindConfigBroadcastRPCAddressDefault creates a FindConfigBroadcastRPCAddressDefault with default headers values

func (*FindConfigBroadcastRPCAddressDefault) Code ¶

Code gets the status code for the find config broadcast rpc address default response

func (*FindConfigBroadcastRPCAddressDefault) Error ¶

func (*FindConfigBroadcastRPCAddressDefault) GetPayload ¶

type FindConfigBroadcastRPCAddressOK ¶

type FindConfigBroadcastRPCAddressOK struct {
	Payload string
}

FindConfigBroadcastRPCAddressOK handles this case with default header values.

Config value

func NewFindConfigBroadcastRPCAddressOK ¶

func NewFindConfigBroadcastRPCAddressOK() *FindConfigBroadcastRPCAddressOK

NewFindConfigBroadcastRPCAddressOK creates a FindConfigBroadcastRPCAddressOK with default headers values

func (*FindConfigBroadcastRPCAddressOK) GetPayload ¶

func (o *FindConfigBroadcastRPCAddressOK) GetPayload() string

type FindConfigBroadcastRPCAddressParams ¶

type FindConfigBroadcastRPCAddressParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigBroadcastRPCAddressParams contains all the parameters to send to the API endpoint for the find config broadcast rpc address operation typically these are written to a http.Request

func NewFindConfigBroadcastRPCAddressParams ¶

func NewFindConfigBroadcastRPCAddressParams() *FindConfigBroadcastRPCAddressParams

NewFindConfigBroadcastRPCAddressParams creates a new FindConfigBroadcastRPCAddressParams object with the default values initialized.

func NewFindConfigBroadcastRPCAddressParamsWithContext ¶

func NewFindConfigBroadcastRPCAddressParamsWithContext(ctx context.Context) *FindConfigBroadcastRPCAddressParams

NewFindConfigBroadcastRPCAddressParamsWithContext creates a new FindConfigBroadcastRPCAddressParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigBroadcastRPCAddressParamsWithHTTPClient ¶

func NewFindConfigBroadcastRPCAddressParamsWithHTTPClient(client *http.Client) *FindConfigBroadcastRPCAddressParams

NewFindConfigBroadcastRPCAddressParamsWithHTTPClient creates a new FindConfigBroadcastRPCAddressParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigBroadcastRPCAddressParamsWithTimeout ¶

func NewFindConfigBroadcastRPCAddressParamsWithTimeout(timeout time.Duration) *FindConfigBroadcastRPCAddressParams

NewFindConfigBroadcastRPCAddressParamsWithTimeout creates a new FindConfigBroadcastRPCAddressParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigBroadcastRPCAddressParams) SetContext ¶

SetContext adds the context to the find config broadcast rpc address params

func (*FindConfigBroadcastRPCAddressParams) SetHTTPClient ¶

func (o *FindConfigBroadcastRPCAddressParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config broadcast rpc address params

func (*FindConfigBroadcastRPCAddressParams) SetTimeout ¶

func (o *FindConfigBroadcastRPCAddressParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config broadcast rpc address params

func (*FindConfigBroadcastRPCAddressParams) WithContext ¶

WithContext adds the context to the find config broadcast rpc address params

func (*FindConfigBroadcastRPCAddressParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config broadcast rpc address params

func (*FindConfigBroadcastRPCAddressParams) WithTimeout ¶

WithTimeout adds the timeout to the find config broadcast rpc address params

func (*FindConfigBroadcastRPCAddressParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigBroadcastRPCAddressReader ¶

type FindConfigBroadcastRPCAddressReader struct {
	// contains filtered or unexported fields
}

FindConfigBroadcastRPCAddressReader is a Reader for the FindConfigBroadcastRPCAddress structure.

func (*FindConfigBroadcastRPCAddressReader) ReadResponse ¶

func (o *FindConfigBroadcastRPCAddressReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCPUSchedulerDefault ¶

type FindConfigCPUSchedulerDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCPUSchedulerDefault handles this case with default header values.

unexpected error

func NewFindConfigCPUSchedulerDefault ¶

func NewFindConfigCPUSchedulerDefault(code int) *FindConfigCPUSchedulerDefault

NewFindConfigCPUSchedulerDefault creates a FindConfigCPUSchedulerDefault with default headers values

func (*FindConfigCPUSchedulerDefault) Code ¶

Code gets the status code for the find config cpu scheduler default response

func (*FindConfigCPUSchedulerDefault) Error ¶

func (*FindConfigCPUSchedulerDefault) GetPayload ¶

type FindConfigCPUSchedulerOK ¶

type FindConfigCPUSchedulerOK struct {
	Payload bool
}

FindConfigCPUSchedulerOK handles this case with default header values.

Config value

func NewFindConfigCPUSchedulerOK ¶

func NewFindConfigCPUSchedulerOK() *FindConfigCPUSchedulerOK

NewFindConfigCPUSchedulerOK creates a FindConfigCPUSchedulerOK with default headers values

func (*FindConfigCPUSchedulerOK) GetPayload ¶

func (o *FindConfigCPUSchedulerOK) GetPayload() bool

type FindConfigCPUSchedulerParams ¶

type FindConfigCPUSchedulerParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCPUSchedulerParams contains all the parameters to send to the API endpoint for the find config cpu scheduler operation typically these are written to a http.Request

func NewFindConfigCPUSchedulerParams ¶

func NewFindConfigCPUSchedulerParams() *FindConfigCPUSchedulerParams

NewFindConfigCPUSchedulerParams creates a new FindConfigCPUSchedulerParams object with the default values initialized.

func NewFindConfigCPUSchedulerParamsWithContext ¶

func NewFindConfigCPUSchedulerParamsWithContext(ctx context.Context) *FindConfigCPUSchedulerParams

NewFindConfigCPUSchedulerParamsWithContext creates a new FindConfigCPUSchedulerParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCPUSchedulerParamsWithHTTPClient ¶

func NewFindConfigCPUSchedulerParamsWithHTTPClient(client *http.Client) *FindConfigCPUSchedulerParams

NewFindConfigCPUSchedulerParamsWithHTTPClient creates a new FindConfigCPUSchedulerParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCPUSchedulerParamsWithTimeout ¶

func NewFindConfigCPUSchedulerParamsWithTimeout(timeout time.Duration) *FindConfigCPUSchedulerParams

NewFindConfigCPUSchedulerParamsWithTimeout creates a new FindConfigCPUSchedulerParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCPUSchedulerParams) SetContext ¶

func (o *FindConfigCPUSchedulerParams) SetContext(ctx context.Context)

SetContext adds the context to the find config cpu scheduler params

func (*FindConfigCPUSchedulerParams) SetHTTPClient ¶

func (o *FindConfigCPUSchedulerParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config cpu scheduler params

func (*FindConfigCPUSchedulerParams) SetTimeout ¶

func (o *FindConfigCPUSchedulerParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config cpu scheduler params

func (*FindConfigCPUSchedulerParams) WithContext ¶

WithContext adds the context to the find config cpu scheduler params

func (*FindConfigCPUSchedulerParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config cpu scheduler params

func (*FindConfigCPUSchedulerParams) WithTimeout ¶

WithTimeout adds the timeout to the find config cpu scheduler params

func (*FindConfigCPUSchedulerParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCPUSchedulerReader ¶

type FindConfigCPUSchedulerReader struct {
	// contains filtered or unexported fields
}

FindConfigCPUSchedulerReader is a Reader for the FindConfigCPUScheduler structure.

func (*FindConfigCPUSchedulerReader) ReadResponse ¶

func (o *FindConfigCPUSchedulerReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCacheHitRateReadBalancingDefault ¶

type FindConfigCacheHitRateReadBalancingDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCacheHitRateReadBalancingDefault handles this case with default header values.

unexpected error

func NewFindConfigCacheHitRateReadBalancingDefault ¶

func NewFindConfigCacheHitRateReadBalancingDefault(code int) *FindConfigCacheHitRateReadBalancingDefault

NewFindConfigCacheHitRateReadBalancingDefault creates a FindConfigCacheHitRateReadBalancingDefault with default headers values

func (*FindConfigCacheHitRateReadBalancingDefault) Code ¶

Code gets the status code for the find config cache hit rate read balancing default response

func (*FindConfigCacheHitRateReadBalancingDefault) Error ¶

func (*FindConfigCacheHitRateReadBalancingDefault) GetPayload ¶

type FindConfigCacheHitRateReadBalancingOK ¶

type FindConfigCacheHitRateReadBalancingOK struct {
	Payload bool
}

FindConfigCacheHitRateReadBalancingOK handles this case with default header values.

Config value

func NewFindConfigCacheHitRateReadBalancingOK ¶

func NewFindConfigCacheHitRateReadBalancingOK() *FindConfigCacheHitRateReadBalancingOK

NewFindConfigCacheHitRateReadBalancingOK creates a FindConfigCacheHitRateReadBalancingOK with default headers values

func (*FindConfigCacheHitRateReadBalancingOK) GetPayload ¶

type FindConfigCacheHitRateReadBalancingParams ¶

type FindConfigCacheHitRateReadBalancingParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCacheHitRateReadBalancingParams contains all the parameters to send to the API endpoint for the find config cache hit rate read balancing operation typically these are written to a http.Request

func NewFindConfigCacheHitRateReadBalancingParams ¶

func NewFindConfigCacheHitRateReadBalancingParams() *FindConfigCacheHitRateReadBalancingParams

NewFindConfigCacheHitRateReadBalancingParams creates a new FindConfigCacheHitRateReadBalancingParams object with the default values initialized.

func NewFindConfigCacheHitRateReadBalancingParamsWithContext ¶

func NewFindConfigCacheHitRateReadBalancingParamsWithContext(ctx context.Context) *FindConfigCacheHitRateReadBalancingParams

NewFindConfigCacheHitRateReadBalancingParamsWithContext creates a new FindConfigCacheHitRateReadBalancingParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCacheHitRateReadBalancingParamsWithHTTPClient ¶

func NewFindConfigCacheHitRateReadBalancingParamsWithHTTPClient(client *http.Client) *FindConfigCacheHitRateReadBalancingParams

NewFindConfigCacheHitRateReadBalancingParamsWithHTTPClient creates a new FindConfigCacheHitRateReadBalancingParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCacheHitRateReadBalancingParamsWithTimeout ¶

func NewFindConfigCacheHitRateReadBalancingParamsWithTimeout(timeout time.Duration) *FindConfigCacheHitRateReadBalancingParams

NewFindConfigCacheHitRateReadBalancingParamsWithTimeout creates a new FindConfigCacheHitRateReadBalancingParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCacheHitRateReadBalancingParams) SetContext ¶

SetContext adds the context to the find config cache hit rate read balancing params

func (*FindConfigCacheHitRateReadBalancingParams) SetHTTPClient ¶

func (o *FindConfigCacheHitRateReadBalancingParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config cache hit rate read balancing params

func (*FindConfigCacheHitRateReadBalancingParams) SetTimeout ¶

SetTimeout adds the timeout to the find config cache hit rate read balancing params

func (*FindConfigCacheHitRateReadBalancingParams) WithContext ¶

WithContext adds the context to the find config cache hit rate read balancing params

func (*FindConfigCacheHitRateReadBalancingParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config cache hit rate read balancing params

func (*FindConfigCacheHitRateReadBalancingParams) WithTimeout ¶

WithTimeout adds the timeout to the find config cache hit rate read balancing params

func (*FindConfigCacheHitRateReadBalancingParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCacheHitRateReadBalancingReader ¶

type FindConfigCacheHitRateReadBalancingReader struct {
	// contains filtered or unexported fields
}

FindConfigCacheHitRateReadBalancingReader is a Reader for the FindConfigCacheHitRateReadBalancing structure.

func (*FindConfigCacheHitRateReadBalancingReader) ReadResponse ¶

func (o *FindConfigCacheHitRateReadBalancingReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCasContentionTimeoutInMsDefault ¶

type FindConfigCasContentionTimeoutInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCasContentionTimeoutInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigCasContentionTimeoutInMsDefault ¶

func NewFindConfigCasContentionTimeoutInMsDefault(code int) *FindConfigCasContentionTimeoutInMsDefault

NewFindConfigCasContentionTimeoutInMsDefault creates a FindConfigCasContentionTimeoutInMsDefault with default headers values

func (*FindConfigCasContentionTimeoutInMsDefault) Code ¶

Code gets the status code for the find config cas contention timeout in ms default response

func (*FindConfigCasContentionTimeoutInMsDefault) Error ¶

func (*FindConfigCasContentionTimeoutInMsDefault) GetPayload ¶

type FindConfigCasContentionTimeoutInMsOK ¶

type FindConfigCasContentionTimeoutInMsOK struct {
	Payload int64
}

FindConfigCasContentionTimeoutInMsOK handles this case with default header values.

Config value

func NewFindConfigCasContentionTimeoutInMsOK ¶

func NewFindConfigCasContentionTimeoutInMsOK() *FindConfigCasContentionTimeoutInMsOK

NewFindConfigCasContentionTimeoutInMsOK creates a FindConfigCasContentionTimeoutInMsOK with default headers values

func (*FindConfigCasContentionTimeoutInMsOK) GetPayload ¶

type FindConfigCasContentionTimeoutInMsParams ¶

type FindConfigCasContentionTimeoutInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCasContentionTimeoutInMsParams contains all the parameters to send to the API endpoint for the find config cas contention timeout in ms operation typically these are written to a http.Request

func NewFindConfigCasContentionTimeoutInMsParams ¶

func NewFindConfigCasContentionTimeoutInMsParams() *FindConfigCasContentionTimeoutInMsParams

NewFindConfigCasContentionTimeoutInMsParams creates a new FindConfigCasContentionTimeoutInMsParams object with the default values initialized.

func NewFindConfigCasContentionTimeoutInMsParamsWithContext ¶

func NewFindConfigCasContentionTimeoutInMsParamsWithContext(ctx context.Context) *FindConfigCasContentionTimeoutInMsParams

NewFindConfigCasContentionTimeoutInMsParamsWithContext creates a new FindConfigCasContentionTimeoutInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCasContentionTimeoutInMsParamsWithHTTPClient ¶

func NewFindConfigCasContentionTimeoutInMsParamsWithHTTPClient(client *http.Client) *FindConfigCasContentionTimeoutInMsParams

NewFindConfigCasContentionTimeoutInMsParamsWithHTTPClient creates a new FindConfigCasContentionTimeoutInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCasContentionTimeoutInMsParamsWithTimeout ¶

func NewFindConfigCasContentionTimeoutInMsParamsWithTimeout(timeout time.Duration) *FindConfigCasContentionTimeoutInMsParams

NewFindConfigCasContentionTimeoutInMsParamsWithTimeout creates a new FindConfigCasContentionTimeoutInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCasContentionTimeoutInMsParams) SetContext ¶

SetContext adds the context to the find config cas contention timeout in ms params

func (*FindConfigCasContentionTimeoutInMsParams) SetHTTPClient ¶

func (o *FindConfigCasContentionTimeoutInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config cas contention timeout in ms params

func (*FindConfigCasContentionTimeoutInMsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config cas contention timeout in ms params

func (*FindConfigCasContentionTimeoutInMsParams) WithContext ¶

WithContext adds the context to the find config cas contention timeout in ms params

func (*FindConfigCasContentionTimeoutInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config cas contention timeout in ms params

func (*FindConfigCasContentionTimeoutInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config cas contention timeout in ms params

func (*FindConfigCasContentionTimeoutInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCasContentionTimeoutInMsReader ¶

type FindConfigCasContentionTimeoutInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigCasContentionTimeoutInMsReader is a Reader for the FindConfigCasContentionTimeoutInMs structure.

func (*FindConfigCasContentionTimeoutInMsReader) ReadResponse ¶

func (o *FindConfigCasContentionTimeoutInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigClientEncryptionOptionsDefault ¶

type FindConfigClientEncryptionOptionsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigClientEncryptionOptionsDefault handles this case with default header values.

unexpected error

func NewFindConfigClientEncryptionOptionsDefault ¶

func NewFindConfigClientEncryptionOptionsDefault(code int) *FindConfigClientEncryptionOptionsDefault

NewFindConfigClientEncryptionOptionsDefault creates a FindConfigClientEncryptionOptionsDefault with default headers values

func (*FindConfigClientEncryptionOptionsDefault) Code ¶

Code gets the status code for the find config client encryption options default response

func (*FindConfigClientEncryptionOptionsDefault) Error ¶

func (*FindConfigClientEncryptionOptionsDefault) GetPayload ¶

type FindConfigClientEncryptionOptionsOK ¶

type FindConfigClientEncryptionOptionsOK struct {
	Payload []string
}

FindConfigClientEncryptionOptionsOK handles this case with default header values.

Config value

func NewFindConfigClientEncryptionOptionsOK ¶

func NewFindConfigClientEncryptionOptionsOK() *FindConfigClientEncryptionOptionsOK

NewFindConfigClientEncryptionOptionsOK creates a FindConfigClientEncryptionOptionsOK with default headers values

func (*FindConfigClientEncryptionOptionsOK) GetPayload ¶

func (o *FindConfigClientEncryptionOptionsOK) GetPayload() []string

type FindConfigClientEncryptionOptionsParams ¶

type FindConfigClientEncryptionOptionsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigClientEncryptionOptionsParams contains all the parameters to send to the API endpoint for the find config client encryption options operation typically these are written to a http.Request

func NewFindConfigClientEncryptionOptionsParams ¶

func NewFindConfigClientEncryptionOptionsParams() *FindConfigClientEncryptionOptionsParams

NewFindConfigClientEncryptionOptionsParams creates a new FindConfigClientEncryptionOptionsParams object with the default values initialized.

func NewFindConfigClientEncryptionOptionsParamsWithContext ¶

func NewFindConfigClientEncryptionOptionsParamsWithContext(ctx context.Context) *FindConfigClientEncryptionOptionsParams

NewFindConfigClientEncryptionOptionsParamsWithContext creates a new FindConfigClientEncryptionOptionsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigClientEncryptionOptionsParamsWithHTTPClient ¶

func NewFindConfigClientEncryptionOptionsParamsWithHTTPClient(client *http.Client) *FindConfigClientEncryptionOptionsParams

NewFindConfigClientEncryptionOptionsParamsWithHTTPClient creates a new FindConfigClientEncryptionOptionsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigClientEncryptionOptionsParamsWithTimeout ¶

func NewFindConfigClientEncryptionOptionsParamsWithTimeout(timeout time.Duration) *FindConfigClientEncryptionOptionsParams

NewFindConfigClientEncryptionOptionsParamsWithTimeout creates a new FindConfigClientEncryptionOptionsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigClientEncryptionOptionsParams) SetContext ¶

SetContext adds the context to the find config client encryption options params

func (*FindConfigClientEncryptionOptionsParams) SetHTTPClient ¶

func (o *FindConfigClientEncryptionOptionsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config client encryption options params

func (*FindConfigClientEncryptionOptionsParams) SetTimeout ¶

func (o *FindConfigClientEncryptionOptionsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config client encryption options params

func (*FindConfigClientEncryptionOptionsParams) WithContext ¶

WithContext adds the context to the find config client encryption options params

func (*FindConfigClientEncryptionOptionsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config client encryption options params

func (*FindConfigClientEncryptionOptionsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config client encryption options params

func (*FindConfigClientEncryptionOptionsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigClientEncryptionOptionsReader ¶

type FindConfigClientEncryptionOptionsReader struct {
	// contains filtered or unexported fields
}

FindConfigClientEncryptionOptionsReader is a Reader for the FindConfigClientEncryptionOptions structure.

func (*FindConfigClientEncryptionOptionsReader) ReadResponse ¶

func (o *FindConfigClientEncryptionOptionsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigClusterNameDefault ¶

type FindConfigClusterNameDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigClusterNameDefault handles this case with default header values.

unexpected error

func NewFindConfigClusterNameDefault ¶

func NewFindConfigClusterNameDefault(code int) *FindConfigClusterNameDefault

NewFindConfigClusterNameDefault creates a FindConfigClusterNameDefault with default headers values

func (*FindConfigClusterNameDefault) Code ¶

Code gets the status code for the find config cluster name default response

func (*FindConfigClusterNameDefault) Error ¶

func (*FindConfigClusterNameDefault) GetPayload ¶

type FindConfigClusterNameOK ¶

type FindConfigClusterNameOK struct {
	Payload string
}

FindConfigClusterNameOK handles this case with default header values.

Config value

func NewFindConfigClusterNameOK ¶

func NewFindConfigClusterNameOK() *FindConfigClusterNameOK

NewFindConfigClusterNameOK creates a FindConfigClusterNameOK with default headers values

func (*FindConfigClusterNameOK) GetPayload ¶

func (o *FindConfigClusterNameOK) GetPayload() string

type FindConfigClusterNameParams ¶

type FindConfigClusterNameParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigClusterNameParams contains all the parameters to send to the API endpoint for the find config cluster name operation typically these are written to a http.Request

func NewFindConfigClusterNameParams ¶

func NewFindConfigClusterNameParams() *FindConfigClusterNameParams

NewFindConfigClusterNameParams creates a new FindConfigClusterNameParams object with the default values initialized.

func NewFindConfigClusterNameParamsWithContext ¶

func NewFindConfigClusterNameParamsWithContext(ctx context.Context) *FindConfigClusterNameParams

NewFindConfigClusterNameParamsWithContext creates a new FindConfigClusterNameParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigClusterNameParamsWithHTTPClient ¶

func NewFindConfigClusterNameParamsWithHTTPClient(client *http.Client) *FindConfigClusterNameParams

NewFindConfigClusterNameParamsWithHTTPClient creates a new FindConfigClusterNameParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigClusterNameParamsWithTimeout ¶

func NewFindConfigClusterNameParamsWithTimeout(timeout time.Duration) *FindConfigClusterNameParams

NewFindConfigClusterNameParamsWithTimeout creates a new FindConfigClusterNameParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigClusterNameParams) SetContext ¶

func (o *FindConfigClusterNameParams) SetContext(ctx context.Context)

SetContext adds the context to the find config cluster name params

func (*FindConfigClusterNameParams) SetHTTPClient ¶

func (o *FindConfigClusterNameParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config cluster name params

func (*FindConfigClusterNameParams) SetTimeout ¶

func (o *FindConfigClusterNameParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config cluster name params

func (*FindConfigClusterNameParams) WithContext ¶

WithContext adds the context to the find config cluster name params

func (*FindConfigClusterNameParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config cluster name params

func (*FindConfigClusterNameParams) WithTimeout ¶

WithTimeout adds the timeout to the find config cluster name params

func (*FindConfigClusterNameParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigClusterNameReader ¶

type FindConfigClusterNameReader struct {
	// contains filtered or unexported fields
}

FindConfigClusterNameReader is a Reader for the FindConfigClusterName structure.

func (*FindConfigClusterNameReader) ReadResponse ¶

func (o *FindConfigClusterNameReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigColumnIndexSizeInKbDefault ¶

type FindConfigColumnIndexSizeInKbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigColumnIndexSizeInKbDefault handles this case with default header values.

unexpected error

func NewFindConfigColumnIndexSizeInKbDefault ¶

func NewFindConfigColumnIndexSizeInKbDefault(code int) *FindConfigColumnIndexSizeInKbDefault

NewFindConfigColumnIndexSizeInKbDefault creates a FindConfigColumnIndexSizeInKbDefault with default headers values

func (*FindConfigColumnIndexSizeInKbDefault) Code ¶

Code gets the status code for the find config column index size in kb default response

func (*FindConfigColumnIndexSizeInKbDefault) Error ¶

func (*FindConfigColumnIndexSizeInKbDefault) GetPayload ¶

type FindConfigColumnIndexSizeInKbOK ¶

type FindConfigColumnIndexSizeInKbOK struct {
	Payload int64
}

FindConfigColumnIndexSizeInKbOK handles this case with default header values.

Config value

func NewFindConfigColumnIndexSizeInKbOK ¶

func NewFindConfigColumnIndexSizeInKbOK() *FindConfigColumnIndexSizeInKbOK

NewFindConfigColumnIndexSizeInKbOK creates a FindConfigColumnIndexSizeInKbOK with default headers values

func (*FindConfigColumnIndexSizeInKbOK) GetPayload ¶

func (o *FindConfigColumnIndexSizeInKbOK) GetPayload() int64

type FindConfigColumnIndexSizeInKbParams ¶

type FindConfigColumnIndexSizeInKbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigColumnIndexSizeInKbParams contains all the parameters to send to the API endpoint for the find config column index size in kb operation typically these are written to a http.Request

func NewFindConfigColumnIndexSizeInKbParams ¶

func NewFindConfigColumnIndexSizeInKbParams() *FindConfigColumnIndexSizeInKbParams

NewFindConfigColumnIndexSizeInKbParams creates a new FindConfigColumnIndexSizeInKbParams object with the default values initialized.

func NewFindConfigColumnIndexSizeInKbParamsWithContext ¶

func NewFindConfigColumnIndexSizeInKbParamsWithContext(ctx context.Context) *FindConfigColumnIndexSizeInKbParams

NewFindConfigColumnIndexSizeInKbParamsWithContext creates a new FindConfigColumnIndexSizeInKbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigColumnIndexSizeInKbParamsWithHTTPClient ¶

func NewFindConfigColumnIndexSizeInKbParamsWithHTTPClient(client *http.Client) *FindConfigColumnIndexSizeInKbParams

NewFindConfigColumnIndexSizeInKbParamsWithHTTPClient creates a new FindConfigColumnIndexSizeInKbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigColumnIndexSizeInKbParamsWithTimeout ¶

func NewFindConfigColumnIndexSizeInKbParamsWithTimeout(timeout time.Duration) *FindConfigColumnIndexSizeInKbParams

NewFindConfigColumnIndexSizeInKbParamsWithTimeout creates a new FindConfigColumnIndexSizeInKbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigColumnIndexSizeInKbParams) SetContext ¶

SetContext adds the context to the find config column index size in kb params

func (*FindConfigColumnIndexSizeInKbParams) SetHTTPClient ¶

func (o *FindConfigColumnIndexSizeInKbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config column index size in kb params

func (*FindConfigColumnIndexSizeInKbParams) SetTimeout ¶

func (o *FindConfigColumnIndexSizeInKbParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config column index size in kb params

func (*FindConfigColumnIndexSizeInKbParams) WithContext ¶

WithContext adds the context to the find config column index size in kb params

func (*FindConfigColumnIndexSizeInKbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config column index size in kb params

func (*FindConfigColumnIndexSizeInKbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config column index size in kb params

func (*FindConfigColumnIndexSizeInKbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigColumnIndexSizeInKbReader ¶

type FindConfigColumnIndexSizeInKbReader struct {
	// contains filtered or unexported fields
}

FindConfigColumnIndexSizeInKbReader is a Reader for the FindConfigColumnIndexSizeInKb structure.

func (*FindConfigColumnIndexSizeInKbReader) ReadResponse ¶

func (o *FindConfigColumnIndexSizeInKbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitFailurePolicyDefault ¶

type FindConfigCommitFailurePolicyDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitFailurePolicyDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitFailurePolicyDefault ¶

func NewFindConfigCommitFailurePolicyDefault(code int) *FindConfigCommitFailurePolicyDefault

NewFindConfigCommitFailurePolicyDefault creates a FindConfigCommitFailurePolicyDefault with default headers values

func (*FindConfigCommitFailurePolicyDefault) Code ¶

Code gets the status code for the find config commit failure policy default response

func (*FindConfigCommitFailurePolicyDefault) Error ¶

func (*FindConfigCommitFailurePolicyDefault) GetPayload ¶

type FindConfigCommitFailurePolicyOK ¶

type FindConfigCommitFailurePolicyOK struct {
	Payload string
}

FindConfigCommitFailurePolicyOK handles this case with default header values.

Config value

func NewFindConfigCommitFailurePolicyOK ¶

func NewFindConfigCommitFailurePolicyOK() *FindConfigCommitFailurePolicyOK

NewFindConfigCommitFailurePolicyOK creates a FindConfigCommitFailurePolicyOK with default headers values

func (*FindConfigCommitFailurePolicyOK) GetPayload ¶

func (o *FindConfigCommitFailurePolicyOK) GetPayload() string

type FindConfigCommitFailurePolicyParams ¶

type FindConfigCommitFailurePolicyParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitFailurePolicyParams contains all the parameters to send to the API endpoint for the find config commit failure policy operation typically these are written to a http.Request

func NewFindConfigCommitFailurePolicyParams ¶

func NewFindConfigCommitFailurePolicyParams() *FindConfigCommitFailurePolicyParams

NewFindConfigCommitFailurePolicyParams creates a new FindConfigCommitFailurePolicyParams object with the default values initialized.

func NewFindConfigCommitFailurePolicyParamsWithContext ¶

func NewFindConfigCommitFailurePolicyParamsWithContext(ctx context.Context) *FindConfigCommitFailurePolicyParams

NewFindConfigCommitFailurePolicyParamsWithContext creates a new FindConfigCommitFailurePolicyParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitFailurePolicyParamsWithHTTPClient ¶

func NewFindConfigCommitFailurePolicyParamsWithHTTPClient(client *http.Client) *FindConfigCommitFailurePolicyParams

NewFindConfigCommitFailurePolicyParamsWithHTTPClient creates a new FindConfigCommitFailurePolicyParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitFailurePolicyParamsWithTimeout ¶

func NewFindConfigCommitFailurePolicyParamsWithTimeout(timeout time.Duration) *FindConfigCommitFailurePolicyParams

NewFindConfigCommitFailurePolicyParamsWithTimeout creates a new FindConfigCommitFailurePolicyParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitFailurePolicyParams) SetContext ¶

SetContext adds the context to the find config commit failure policy params

func (*FindConfigCommitFailurePolicyParams) SetHTTPClient ¶

func (o *FindConfigCommitFailurePolicyParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commit failure policy params

func (*FindConfigCommitFailurePolicyParams) SetTimeout ¶

func (o *FindConfigCommitFailurePolicyParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config commit failure policy params

func (*FindConfigCommitFailurePolicyParams) WithContext ¶

WithContext adds the context to the find config commit failure policy params

func (*FindConfigCommitFailurePolicyParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commit failure policy params

func (*FindConfigCommitFailurePolicyParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commit failure policy params

func (*FindConfigCommitFailurePolicyParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitFailurePolicyReader ¶

type FindConfigCommitFailurePolicyReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitFailurePolicyReader is a Reader for the FindConfigCommitFailurePolicy structure.

func (*FindConfigCommitFailurePolicyReader) ReadResponse ¶

func (o *FindConfigCommitFailurePolicyReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitlogDirectoryDefault ¶

type FindConfigCommitlogDirectoryDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitlogDirectoryDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitlogDirectoryDefault ¶

func NewFindConfigCommitlogDirectoryDefault(code int) *FindConfigCommitlogDirectoryDefault

NewFindConfigCommitlogDirectoryDefault creates a FindConfigCommitlogDirectoryDefault with default headers values

func (*FindConfigCommitlogDirectoryDefault) Code ¶

Code gets the status code for the find config commitlog directory default response

func (*FindConfigCommitlogDirectoryDefault) Error ¶

func (*FindConfigCommitlogDirectoryDefault) GetPayload ¶

type FindConfigCommitlogDirectoryOK ¶

type FindConfigCommitlogDirectoryOK struct {
	Payload string
}

FindConfigCommitlogDirectoryOK handles this case with default header values.

Config value

func NewFindConfigCommitlogDirectoryOK ¶

func NewFindConfigCommitlogDirectoryOK() *FindConfigCommitlogDirectoryOK

NewFindConfigCommitlogDirectoryOK creates a FindConfigCommitlogDirectoryOK with default headers values

func (*FindConfigCommitlogDirectoryOK) GetPayload ¶

func (o *FindConfigCommitlogDirectoryOK) GetPayload() string

type FindConfigCommitlogDirectoryParams ¶

type FindConfigCommitlogDirectoryParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitlogDirectoryParams contains all the parameters to send to the API endpoint for the find config commitlog directory operation typically these are written to a http.Request

func NewFindConfigCommitlogDirectoryParams ¶

func NewFindConfigCommitlogDirectoryParams() *FindConfigCommitlogDirectoryParams

NewFindConfigCommitlogDirectoryParams creates a new FindConfigCommitlogDirectoryParams object with the default values initialized.

func NewFindConfigCommitlogDirectoryParamsWithContext ¶

func NewFindConfigCommitlogDirectoryParamsWithContext(ctx context.Context) *FindConfigCommitlogDirectoryParams

NewFindConfigCommitlogDirectoryParamsWithContext creates a new FindConfigCommitlogDirectoryParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitlogDirectoryParamsWithHTTPClient ¶

func NewFindConfigCommitlogDirectoryParamsWithHTTPClient(client *http.Client) *FindConfigCommitlogDirectoryParams

NewFindConfigCommitlogDirectoryParamsWithHTTPClient creates a new FindConfigCommitlogDirectoryParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitlogDirectoryParamsWithTimeout ¶

func NewFindConfigCommitlogDirectoryParamsWithTimeout(timeout time.Duration) *FindConfigCommitlogDirectoryParams

NewFindConfigCommitlogDirectoryParamsWithTimeout creates a new FindConfigCommitlogDirectoryParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitlogDirectoryParams) SetContext ¶

SetContext adds the context to the find config commitlog directory params

func (*FindConfigCommitlogDirectoryParams) SetHTTPClient ¶

func (o *FindConfigCommitlogDirectoryParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commitlog directory params

func (*FindConfigCommitlogDirectoryParams) SetTimeout ¶

func (o *FindConfigCommitlogDirectoryParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config commitlog directory params

func (*FindConfigCommitlogDirectoryParams) WithContext ¶

WithContext adds the context to the find config commitlog directory params

func (*FindConfigCommitlogDirectoryParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commitlog directory params

func (*FindConfigCommitlogDirectoryParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commitlog directory params

func (*FindConfigCommitlogDirectoryParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitlogDirectoryReader ¶

type FindConfigCommitlogDirectoryReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitlogDirectoryReader is a Reader for the FindConfigCommitlogDirectory structure.

func (*FindConfigCommitlogDirectoryReader) ReadResponse ¶

func (o *FindConfigCommitlogDirectoryReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitlogReuseSegmentsDefault ¶

type FindConfigCommitlogReuseSegmentsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitlogReuseSegmentsDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitlogReuseSegmentsDefault ¶

func NewFindConfigCommitlogReuseSegmentsDefault(code int) *FindConfigCommitlogReuseSegmentsDefault

NewFindConfigCommitlogReuseSegmentsDefault creates a FindConfigCommitlogReuseSegmentsDefault with default headers values

func (*FindConfigCommitlogReuseSegmentsDefault) Code ¶

Code gets the status code for the find config commitlog reuse segments default response

func (*FindConfigCommitlogReuseSegmentsDefault) Error ¶

func (*FindConfigCommitlogReuseSegmentsDefault) GetPayload ¶

type FindConfigCommitlogReuseSegmentsOK ¶

type FindConfigCommitlogReuseSegmentsOK struct {
	Payload bool
}

FindConfigCommitlogReuseSegmentsOK handles this case with default header values.

Config value

func NewFindConfigCommitlogReuseSegmentsOK ¶

func NewFindConfigCommitlogReuseSegmentsOK() *FindConfigCommitlogReuseSegmentsOK

NewFindConfigCommitlogReuseSegmentsOK creates a FindConfigCommitlogReuseSegmentsOK with default headers values

func (*FindConfigCommitlogReuseSegmentsOK) GetPayload ¶

func (o *FindConfigCommitlogReuseSegmentsOK) GetPayload() bool

type FindConfigCommitlogReuseSegmentsParams ¶

type FindConfigCommitlogReuseSegmentsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitlogReuseSegmentsParams contains all the parameters to send to the API endpoint for the find config commitlog reuse segments operation typically these are written to a http.Request

func NewFindConfigCommitlogReuseSegmentsParams ¶

func NewFindConfigCommitlogReuseSegmentsParams() *FindConfigCommitlogReuseSegmentsParams

NewFindConfigCommitlogReuseSegmentsParams creates a new FindConfigCommitlogReuseSegmentsParams object with the default values initialized.

func NewFindConfigCommitlogReuseSegmentsParamsWithContext ¶

func NewFindConfigCommitlogReuseSegmentsParamsWithContext(ctx context.Context) *FindConfigCommitlogReuseSegmentsParams

NewFindConfigCommitlogReuseSegmentsParamsWithContext creates a new FindConfigCommitlogReuseSegmentsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitlogReuseSegmentsParamsWithHTTPClient ¶

func NewFindConfigCommitlogReuseSegmentsParamsWithHTTPClient(client *http.Client) *FindConfigCommitlogReuseSegmentsParams

NewFindConfigCommitlogReuseSegmentsParamsWithHTTPClient creates a new FindConfigCommitlogReuseSegmentsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitlogReuseSegmentsParamsWithTimeout ¶

func NewFindConfigCommitlogReuseSegmentsParamsWithTimeout(timeout time.Duration) *FindConfigCommitlogReuseSegmentsParams

NewFindConfigCommitlogReuseSegmentsParamsWithTimeout creates a new FindConfigCommitlogReuseSegmentsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitlogReuseSegmentsParams) SetContext ¶

SetContext adds the context to the find config commitlog reuse segments params

func (*FindConfigCommitlogReuseSegmentsParams) SetHTTPClient ¶

func (o *FindConfigCommitlogReuseSegmentsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commitlog reuse segments params

func (*FindConfigCommitlogReuseSegmentsParams) SetTimeout ¶

func (o *FindConfigCommitlogReuseSegmentsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config commitlog reuse segments params

func (*FindConfigCommitlogReuseSegmentsParams) WithContext ¶

WithContext adds the context to the find config commitlog reuse segments params

func (*FindConfigCommitlogReuseSegmentsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commitlog reuse segments params

func (*FindConfigCommitlogReuseSegmentsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commitlog reuse segments params

func (*FindConfigCommitlogReuseSegmentsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitlogReuseSegmentsReader ¶

type FindConfigCommitlogReuseSegmentsReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitlogReuseSegmentsReader is a Reader for the FindConfigCommitlogReuseSegments structure.

func (*FindConfigCommitlogReuseSegmentsReader) ReadResponse ¶

func (o *FindConfigCommitlogReuseSegmentsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitlogSegmentSizeInMbDefault ¶

type FindConfigCommitlogSegmentSizeInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitlogSegmentSizeInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitlogSegmentSizeInMbDefault ¶

func NewFindConfigCommitlogSegmentSizeInMbDefault(code int) *FindConfigCommitlogSegmentSizeInMbDefault

NewFindConfigCommitlogSegmentSizeInMbDefault creates a FindConfigCommitlogSegmentSizeInMbDefault with default headers values

func (*FindConfigCommitlogSegmentSizeInMbDefault) Code ¶

Code gets the status code for the find config commitlog segment size in mb default response

func (*FindConfigCommitlogSegmentSizeInMbDefault) Error ¶

func (*FindConfigCommitlogSegmentSizeInMbDefault) GetPayload ¶

type FindConfigCommitlogSegmentSizeInMbOK ¶

type FindConfigCommitlogSegmentSizeInMbOK struct {
	Payload int64
}

FindConfigCommitlogSegmentSizeInMbOK handles this case with default header values.

Config value

func NewFindConfigCommitlogSegmentSizeInMbOK ¶

func NewFindConfigCommitlogSegmentSizeInMbOK() *FindConfigCommitlogSegmentSizeInMbOK

NewFindConfigCommitlogSegmentSizeInMbOK creates a FindConfigCommitlogSegmentSizeInMbOK with default headers values

func (*FindConfigCommitlogSegmentSizeInMbOK) GetPayload ¶

type FindConfigCommitlogSegmentSizeInMbParams ¶

type FindConfigCommitlogSegmentSizeInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitlogSegmentSizeInMbParams contains all the parameters to send to the API endpoint for the find config commitlog segment size in mb operation typically these are written to a http.Request

func NewFindConfigCommitlogSegmentSizeInMbParams ¶

func NewFindConfigCommitlogSegmentSizeInMbParams() *FindConfigCommitlogSegmentSizeInMbParams

NewFindConfigCommitlogSegmentSizeInMbParams creates a new FindConfigCommitlogSegmentSizeInMbParams object with the default values initialized.

func NewFindConfigCommitlogSegmentSizeInMbParamsWithContext ¶

func NewFindConfigCommitlogSegmentSizeInMbParamsWithContext(ctx context.Context) *FindConfigCommitlogSegmentSizeInMbParams

NewFindConfigCommitlogSegmentSizeInMbParamsWithContext creates a new FindConfigCommitlogSegmentSizeInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitlogSegmentSizeInMbParamsWithHTTPClient ¶

func NewFindConfigCommitlogSegmentSizeInMbParamsWithHTTPClient(client *http.Client) *FindConfigCommitlogSegmentSizeInMbParams

NewFindConfigCommitlogSegmentSizeInMbParamsWithHTTPClient creates a new FindConfigCommitlogSegmentSizeInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitlogSegmentSizeInMbParamsWithTimeout ¶

func NewFindConfigCommitlogSegmentSizeInMbParamsWithTimeout(timeout time.Duration) *FindConfigCommitlogSegmentSizeInMbParams

NewFindConfigCommitlogSegmentSizeInMbParamsWithTimeout creates a new FindConfigCommitlogSegmentSizeInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitlogSegmentSizeInMbParams) SetContext ¶

SetContext adds the context to the find config commitlog segment size in mb params

func (*FindConfigCommitlogSegmentSizeInMbParams) SetHTTPClient ¶

func (o *FindConfigCommitlogSegmentSizeInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commitlog segment size in mb params

func (*FindConfigCommitlogSegmentSizeInMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config commitlog segment size in mb params

func (*FindConfigCommitlogSegmentSizeInMbParams) WithContext ¶

WithContext adds the context to the find config commitlog segment size in mb params

func (*FindConfigCommitlogSegmentSizeInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commitlog segment size in mb params

func (*FindConfigCommitlogSegmentSizeInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commitlog segment size in mb params

func (*FindConfigCommitlogSegmentSizeInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitlogSegmentSizeInMbReader ¶

type FindConfigCommitlogSegmentSizeInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitlogSegmentSizeInMbReader is a Reader for the FindConfigCommitlogSegmentSizeInMb structure.

func (*FindConfigCommitlogSegmentSizeInMbReader) ReadResponse ¶

func (o *FindConfigCommitlogSegmentSizeInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitlogSyncBatchWindowInMsDefault ¶

type FindConfigCommitlogSyncBatchWindowInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncBatchWindowInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitlogSyncBatchWindowInMsDefault ¶

func NewFindConfigCommitlogSyncBatchWindowInMsDefault(code int) *FindConfigCommitlogSyncBatchWindowInMsDefault

NewFindConfigCommitlogSyncBatchWindowInMsDefault creates a FindConfigCommitlogSyncBatchWindowInMsDefault with default headers values

func (*FindConfigCommitlogSyncBatchWindowInMsDefault) Code ¶

Code gets the status code for the find config commitlog sync batch window in ms default response

func (*FindConfigCommitlogSyncBatchWindowInMsDefault) Error ¶

func (*FindConfigCommitlogSyncBatchWindowInMsDefault) GetPayload ¶

type FindConfigCommitlogSyncBatchWindowInMsOK ¶

type FindConfigCommitlogSyncBatchWindowInMsOK struct {
	Payload int64
}

FindConfigCommitlogSyncBatchWindowInMsOK handles this case with default header values.

Config value

func NewFindConfigCommitlogSyncBatchWindowInMsOK ¶

func NewFindConfigCommitlogSyncBatchWindowInMsOK() *FindConfigCommitlogSyncBatchWindowInMsOK

NewFindConfigCommitlogSyncBatchWindowInMsOK creates a FindConfigCommitlogSyncBatchWindowInMsOK with default headers values

func (*FindConfigCommitlogSyncBatchWindowInMsOK) GetPayload ¶

type FindConfigCommitlogSyncBatchWindowInMsParams ¶

type FindConfigCommitlogSyncBatchWindowInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncBatchWindowInMsParams contains all the parameters to send to the API endpoint for the find config commitlog sync batch window in ms operation typically these are written to a http.Request

func NewFindConfigCommitlogSyncBatchWindowInMsParams ¶

func NewFindConfigCommitlogSyncBatchWindowInMsParams() *FindConfigCommitlogSyncBatchWindowInMsParams

NewFindConfigCommitlogSyncBatchWindowInMsParams creates a new FindConfigCommitlogSyncBatchWindowInMsParams object with the default values initialized.

func NewFindConfigCommitlogSyncBatchWindowInMsParamsWithContext ¶

func NewFindConfigCommitlogSyncBatchWindowInMsParamsWithContext(ctx context.Context) *FindConfigCommitlogSyncBatchWindowInMsParams

NewFindConfigCommitlogSyncBatchWindowInMsParamsWithContext creates a new FindConfigCommitlogSyncBatchWindowInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitlogSyncBatchWindowInMsParamsWithHTTPClient ¶

func NewFindConfigCommitlogSyncBatchWindowInMsParamsWithHTTPClient(client *http.Client) *FindConfigCommitlogSyncBatchWindowInMsParams

NewFindConfigCommitlogSyncBatchWindowInMsParamsWithHTTPClient creates a new FindConfigCommitlogSyncBatchWindowInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitlogSyncBatchWindowInMsParamsWithTimeout ¶

func NewFindConfigCommitlogSyncBatchWindowInMsParamsWithTimeout(timeout time.Duration) *FindConfigCommitlogSyncBatchWindowInMsParams

NewFindConfigCommitlogSyncBatchWindowInMsParamsWithTimeout creates a new FindConfigCommitlogSyncBatchWindowInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitlogSyncBatchWindowInMsParams) SetContext ¶

SetContext adds the context to the find config commitlog sync batch window in ms params

func (*FindConfigCommitlogSyncBatchWindowInMsParams) SetHTTPClient ¶

func (o *FindConfigCommitlogSyncBatchWindowInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commitlog sync batch window in ms params

func (*FindConfigCommitlogSyncBatchWindowInMsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config commitlog sync batch window in ms params

func (*FindConfigCommitlogSyncBatchWindowInMsParams) WithContext ¶

WithContext adds the context to the find config commitlog sync batch window in ms params

func (*FindConfigCommitlogSyncBatchWindowInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commitlog sync batch window in ms params

func (*FindConfigCommitlogSyncBatchWindowInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commitlog sync batch window in ms params

func (*FindConfigCommitlogSyncBatchWindowInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitlogSyncBatchWindowInMsReader ¶

type FindConfigCommitlogSyncBatchWindowInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncBatchWindowInMsReader is a Reader for the FindConfigCommitlogSyncBatchWindowInMs structure.

func (*FindConfigCommitlogSyncBatchWindowInMsReader) ReadResponse ¶

func (o *FindConfigCommitlogSyncBatchWindowInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitlogSyncDefault ¶

type FindConfigCommitlogSyncDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitlogSyncDefault ¶

func NewFindConfigCommitlogSyncDefault(code int) *FindConfigCommitlogSyncDefault

NewFindConfigCommitlogSyncDefault creates a FindConfigCommitlogSyncDefault with default headers values

func (*FindConfigCommitlogSyncDefault) Code ¶

Code gets the status code for the find config commitlog sync default response

func (*FindConfigCommitlogSyncDefault) Error ¶

func (*FindConfigCommitlogSyncDefault) GetPayload ¶

type FindConfigCommitlogSyncOK ¶

type FindConfigCommitlogSyncOK struct {
	Payload string
}

FindConfigCommitlogSyncOK handles this case with default header values.

Config value

func NewFindConfigCommitlogSyncOK ¶

func NewFindConfigCommitlogSyncOK() *FindConfigCommitlogSyncOK

NewFindConfigCommitlogSyncOK creates a FindConfigCommitlogSyncOK with default headers values

func (*FindConfigCommitlogSyncOK) GetPayload ¶

func (o *FindConfigCommitlogSyncOK) GetPayload() string

type FindConfigCommitlogSyncParams ¶

type FindConfigCommitlogSyncParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncParams contains all the parameters to send to the API endpoint for the find config commitlog sync operation typically these are written to a http.Request

func NewFindConfigCommitlogSyncParams ¶

func NewFindConfigCommitlogSyncParams() *FindConfigCommitlogSyncParams

NewFindConfigCommitlogSyncParams creates a new FindConfigCommitlogSyncParams object with the default values initialized.

func NewFindConfigCommitlogSyncParamsWithContext ¶

func NewFindConfigCommitlogSyncParamsWithContext(ctx context.Context) *FindConfigCommitlogSyncParams

NewFindConfigCommitlogSyncParamsWithContext creates a new FindConfigCommitlogSyncParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitlogSyncParamsWithHTTPClient ¶

func NewFindConfigCommitlogSyncParamsWithHTTPClient(client *http.Client) *FindConfigCommitlogSyncParams

NewFindConfigCommitlogSyncParamsWithHTTPClient creates a new FindConfigCommitlogSyncParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitlogSyncParamsWithTimeout ¶

func NewFindConfigCommitlogSyncParamsWithTimeout(timeout time.Duration) *FindConfigCommitlogSyncParams

NewFindConfigCommitlogSyncParamsWithTimeout creates a new FindConfigCommitlogSyncParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitlogSyncParams) SetContext ¶

func (o *FindConfigCommitlogSyncParams) SetContext(ctx context.Context)

SetContext adds the context to the find config commitlog sync params

func (*FindConfigCommitlogSyncParams) SetHTTPClient ¶

func (o *FindConfigCommitlogSyncParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commitlog sync params

func (*FindConfigCommitlogSyncParams) SetTimeout ¶

func (o *FindConfigCommitlogSyncParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config commitlog sync params

func (*FindConfigCommitlogSyncParams) WithContext ¶

WithContext adds the context to the find config commitlog sync params

func (*FindConfigCommitlogSyncParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commitlog sync params

func (*FindConfigCommitlogSyncParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commitlog sync params

func (*FindConfigCommitlogSyncParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitlogSyncPeriodInMsDefault ¶

type FindConfigCommitlogSyncPeriodInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncPeriodInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitlogSyncPeriodInMsDefault ¶

func NewFindConfigCommitlogSyncPeriodInMsDefault(code int) *FindConfigCommitlogSyncPeriodInMsDefault

NewFindConfigCommitlogSyncPeriodInMsDefault creates a FindConfigCommitlogSyncPeriodInMsDefault with default headers values

func (*FindConfigCommitlogSyncPeriodInMsDefault) Code ¶

Code gets the status code for the find config commitlog sync period in ms default response

func (*FindConfigCommitlogSyncPeriodInMsDefault) Error ¶

func (*FindConfigCommitlogSyncPeriodInMsDefault) GetPayload ¶

type FindConfigCommitlogSyncPeriodInMsOK ¶

type FindConfigCommitlogSyncPeriodInMsOK struct {
	Payload int64
}

FindConfigCommitlogSyncPeriodInMsOK handles this case with default header values.

Config value

func NewFindConfigCommitlogSyncPeriodInMsOK ¶

func NewFindConfigCommitlogSyncPeriodInMsOK() *FindConfigCommitlogSyncPeriodInMsOK

NewFindConfigCommitlogSyncPeriodInMsOK creates a FindConfigCommitlogSyncPeriodInMsOK with default headers values

func (*FindConfigCommitlogSyncPeriodInMsOK) GetPayload ¶

type FindConfigCommitlogSyncPeriodInMsParams ¶

type FindConfigCommitlogSyncPeriodInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncPeriodInMsParams contains all the parameters to send to the API endpoint for the find config commitlog sync period in ms operation typically these are written to a http.Request

func NewFindConfigCommitlogSyncPeriodInMsParams ¶

func NewFindConfigCommitlogSyncPeriodInMsParams() *FindConfigCommitlogSyncPeriodInMsParams

NewFindConfigCommitlogSyncPeriodInMsParams creates a new FindConfigCommitlogSyncPeriodInMsParams object with the default values initialized.

func NewFindConfigCommitlogSyncPeriodInMsParamsWithContext ¶

func NewFindConfigCommitlogSyncPeriodInMsParamsWithContext(ctx context.Context) *FindConfigCommitlogSyncPeriodInMsParams

NewFindConfigCommitlogSyncPeriodInMsParamsWithContext creates a new FindConfigCommitlogSyncPeriodInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitlogSyncPeriodInMsParamsWithHTTPClient ¶

func NewFindConfigCommitlogSyncPeriodInMsParamsWithHTTPClient(client *http.Client) *FindConfigCommitlogSyncPeriodInMsParams

NewFindConfigCommitlogSyncPeriodInMsParamsWithHTTPClient creates a new FindConfigCommitlogSyncPeriodInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitlogSyncPeriodInMsParamsWithTimeout ¶

func NewFindConfigCommitlogSyncPeriodInMsParamsWithTimeout(timeout time.Duration) *FindConfigCommitlogSyncPeriodInMsParams

NewFindConfigCommitlogSyncPeriodInMsParamsWithTimeout creates a new FindConfigCommitlogSyncPeriodInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitlogSyncPeriodInMsParams) SetContext ¶

SetContext adds the context to the find config commitlog sync period in ms params

func (*FindConfigCommitlogSyncPeriodInMsParams) SetHTTPClient ¶

func (o *FindConfigCommitlogSyncPeriodInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commitlog sync period in ms params

func (*FindConfigCommitlogSyncPeriodInMsParams) SetTimeout ¶

func (o *FindConfigCommitlogSyncPeriodInMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config commitlog sync period in ms params

func (*FindConfigCommitlogSyncPeriodInMsParams) WithContext ¶

WithContext adds the context to the find config commitlog sync period in ms params

func (*FindConfigCommitlogSyncPeriodInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commitlog sync period in ms params

func (*FindConfigCommitlogSyncPeriodInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commitlog sync period in ms params

func (*FindConfigCommitlogSyncPeriodInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitlogSyncPeriodInMsReader ¶

type FindConfigCommitlogSyncPeriodInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncPeriodInMsReader is a Reader for the FindConfigCommitlogSyncPeriodInMs structure.

func (*FindConfigCommitlogSyncPeriodInMsReader) ReadResponse ¶

func (o *FindConfigCommitlogSyncPeriodInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitlogSyncReader ¶

type FindConfigCommitlogSyncReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitlogSyncReader is a Reader for the FindConfigCommitlogSync structure.

func (*FindConfigCommitlogSyncReader) ReadResponse ¶

func (o *FindConfigCommitlogSyncReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitlogTotalSpaceInMbDefault ¶

type FindConfigCommitlogTotalSpaceInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitlogTotalSpaceInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitlogTotalSpaceInMbDefault ¶

func NewFindConfigCommitlogTotalSpaceInMbDefault(code int) *FindConfigCommitlogTotalSpaceInMbDefault

NewFindConfigCommitlogTotalSpaceInMbDefault creates a FindConfigCommitlogTotalSpaceInMbDefault with default headers values

func (*FindConfigCommitlogTotalSpaceInMbDefault) Code ¶

Code gets the status code for the find config commitlog total space in mb default response

func (*FindConfigCommitlogTotalSpaceInMbDefault) Error ¶

func (*FindConfigCommitlogTotalSpaceInMbDefault) GetPayload ¶

type FindConfigCommitlogTotalSpaceInMbOK ¶

type FindConfigCommitlogTotalSpaceInMbOK struct {
	Payload int64
}

FindConfigCommitlogTotalSpaceInMbOK handles this case with default header values.

Config value

func NewFindConfigCommitlogTotalSpaceInMbOK ¶

func NewFindConfigCommitlogTotalSpaceInMbOK() *FindConfigCommitlogTotalSpaceInMbOK

NewFindConfigCommitlogTotalSpaceInMbOK creates a FindConfigCommitlogTotalSpaceInMbOK with default headers values

func (*FindConfigCommitlogTotalSpaceInMbOK) GetPayload ¶

type FindConfigCommitlogTotalSpaceInMbParams ¶

type FindConfigCommitlogTotalSpaceInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitlogTotalSpaceInMbParams contains all the parameters to send to the API endpoint for the find config commitlog total space in mb operation typically these are written to a http.Request

func NewFindConfigCommitlogTotalSpaceInMbParams ¶

func NewFindConfigCommitlogTotalSpaceInMbParams() *FindConfigCommitlogTotalSpaceInMbParams

NewFindConfigCommitlogTotalSpaceInMbParams creates a new FindConfigCommitlogTotalSpaceInMbParams object with the default values initialized.

func NewFindConfigCommitlogTotalSpaceInMbParamsWithContext ¶

func NewFindConfigCommitlogTotalSpaceInMbParamsWithContext(ctx context.Context) *FindConfigCommitlogTotalSpaceInMbParams

NewFindConfigCommitlogTotalSpaceInMbParamsWithContext creates a new FindConfigCommitlogTotalSpaceInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitlogTotalSpaceInMbParamsWithHTTPClient ¶

func NewFindConfigCommitlogTotalSpaceInMbParamsWithHTTPClient(client *http.Client) *FindConfigCommitlogTotalSpaceInMbParams

NewFindConfigCommitlogTotalSpaceInMbParamsWithHTTPClient creates a new FindConfigCommitlogTotalSpaceInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitlogTotalSpaceInMbParamsWithTimeout ¶

func NewFindConfigCommitlogTotalSpaceInMbParamsWithTimeout(timeout time.Duration) *FindConfigCommitlogTotalSpaceInMbParams

NewFindConfigCommitlogTotalSpaceInMbParamsWithTimeout creates a new FindConfigCommitlogTotalSpaceInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitlogTotalSpaceInMbParams) SetContext ¶

SetContext adds the context to the find config commitlog total space in mb params

func (*FindConfigCommitlogTotalSpaceInMbParams) SetHTTPClient ¶

func (o *FindConfigCommitlogTotalSpaceInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commitlog total space in mb params

func (*FindConfigCommitlogTotalSpaceInMbParams) SetTimeout ¶

func (o *FindConfigCommitlogTotalSpaceInMbParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config commitlog total space in mb params

func (*FindConfigCommitlogTotalSpaceInMbParams) WithContext ¶

WithContext adds the context to the find config commitlog total space in mb params

func (*FindConfigCommitlogTotalSpaceInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commitlog total space in mb params

func (*FindConfigCommitlogTotalSpaceInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commitlog total space in mb params

func (*FindConfigCommitlogTotalSpaceInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitlogTotalSpaceInMbReader ¶

type FindConfigCommitlogTotalSpaceInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitlogTotalSpaceInMbReader is a Reader for the FindConfigCommitlogTotalSpaceInMb structure.

func (*FindConfigCommitlogTotalSpaceInMbReader) ReadResponse ¶

func (o *FindConfigCommitlogTotalSpaceInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCommitlogUseODsyncOK ¶

type FindConfigCommitlogUseODsyncOK struct {
	Payload bool
}

FindConfigCommitlogUseODsyncOK handles this case with default header values.

Config value

func NewFindConfigCommitlogUseODsyncOK ¶

func NewFindConfigCommitlogUseODsyncOK() *FindConfigCommitlogUseODsyncOK

NewFindConfigCommitlogUseODsyncOK creates a FindConfigCommitlogUseODsyncOK with default headers values

func (*FindConfigCommitlogUseODsyncOK) GetPayload ¶

func (o *FindConfigCommitlogUseODsyncOK) GetPayload() bool

type FindConfigCommitlogUseoDsyncDefault ¶

type FindConfigCommitlogUseoDsyncDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCommitlogUseoDsyncDefault handles this case with default header values.

unexpected error

func NewFindConfigCommitlogUseoDsyncDefault ¶

func NewFindConfigCommitlogUseoDsyncDefault(code int) *FindConfigCommitlogUseoDsyncDefault

NewFindConfigCommitlogUseoDsyncDefault creates a FindConfigCommitlogUseoDsyncDefault with default headers values

func (*FindConfigCommitlogUseoDsyncDefault) Code ¶

Code gets the status code for the find config commitlog use o dsync default response

func (*FindConfigCommitlogUseoDsyncDefault) Error ¶

func (*FindConfigCommitlogUseoDsyncDefault) GetPayload ¶

type FindConfigCommitlogUseoDsyncParams ¶

type FindConfigCommitlogUseoDsyncParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCommitlogUseoDsyncParams contains all the parameters to send to the API endpoint for the find config commitlog use o dsync operation typically these are written to a http.Request

func NewFindConfigCommitlogUseoDsyncParams ¶

func NewFindConfigCommitlogUseoDsyncParams() *FindConfigCommitlogUseoDsyncParams

NewFindConfigCommitlogUseoDsyncParams creates a new FindConfigCommitlogUseoDsyncParams object with the default values initialized.

func NewFindConfigCommitlogUseoDsyncParamsWithContext ¶

func NewFindConfigCommitlogUseoDsyncParamsWithContext(ctx context.Context) *FindConfigCommitlogUseoDsyncParams

NewFindConfigCommitlogUseoDsyncParamsWithContext creates a new FindConfigCommitlogUseoDsyncParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCommitlogUseoDsyncParamsWithHTTPClient ¶

func NewFindConfigCommitlogUseoDsyncParamsWithHTTPClient(client *http.Client) *FindConfigCommitlogUseoDsyncParams

NewFindConfigCommitlogUseoDsyncParamsWithHTTPClient creates a new FindConfigCommitlogUseoDsyncParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCommitlogUseoDsyncParamsWithTimeout ¶

func NewFindConfigCommitlogUseoDsyncParamsWithTimeout(timeout time.Duration) *FindConfigCommitlogUseoDsyncParams

NewFindConfigCommitlogUseoDsyncParamsWithTimeout creates a new FindConfigCommitlogUseoDsyncParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCommitlogUseoDsyncParams) SetContext ¶

SetContext adds the context to the find config commitlog use o dsync params

func (*FindConfigCommitlogUseoDsyncParams) SetHTTPClient ¶

func (o *FindConfigCommitlogUseoDsyncParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config commitlog use o dsync params

func (*FindConfigCommitlogUseoDsyncParams) SetTimeout ¶

func (o *FindConfigCommitlogUseoDsyncParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config commitlog use o dsync params

func (*FindConfigCommitlogUseoDsyncParams) WithContext ¶

WithContext adds the context to the find config commitlog use o dsync params

func (*FindConfigCommitlogUseoDsyncParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config commitlog use o dsync params

func (*FindConfigCommitlogUseoDsyncParams) WithTimeout ¶

WithTimeout adds the timeout to the find config commitlog use o dsync params

func (*FindConfigCommitlogUseoDsyncParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCommitlogUseoDsyncReader ¶

type FindConfigCommitlogUseoDsyncReader struct {
	// contains filtered or unexported fields
}

FindConfigCommitlogUseoDsyncReader is a Reader for the FindConfigCommitlogUseoDsync structure.

func (*FindConfigCommitlogUseoDsyncReader) ReadResponse ¶

func (o *FindConfigCommitlogUseoDsyncReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCompactionEnforceMinThresholdDefault ¶

type FindConfigCompactionEnforceMinThresholdDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCompactionEnforceMinThresholdDefault handles this case with default header values.

unexpected error

func NewFindConfigCompactionEnforceMinThresholdDefault ¶

func NewFindConfigCompactionEnforceMinThresholdDefault(code int) *FindConfigCompactionEnforceMinThresholdDefault

NewFindConfigCompactionEnforceMinThresholdDefault creates a FindConfigCompactionEnforceMinThresholdDefault with default headers values

func (*FindConfigCompactionEnforceMinThresholdDefault) Code ¶

Code gets the status code for the find config compaction enforce min threshold default response

func (*FindConfigCompactionEnforceMinThresholdDefault) Error ¶

func (*FindConfigCompactionEnforceMinThresholdDefault) GetPayload ¶

type FindConfigCompactionEnforceMinThresholdOK ¶

type FindConfigCompactionEnforceMinThresholdOK struct {
	Payload bool
}

FindConfigCompactionEnforceMinThresholdOK handles this case with default header values.

Config value

func NewFindConfigCompactionEnforceMinThresholdOK ¶

func NewFindConfigCompactionEnforceMinThresholdOK() *FindConfigCompactionEnforceMinThresholdOK

NewFindConfigCompactionEnforceMinThresholdOK creates a FindConfigCompactionEnforceMinThresholdOK with default headers values

func (*FindConfigCompactionEnforceMinThresholdOK) GetPayload ¶

type FindConfigCompactionEnforceMinThresholdParams ¶

type FindConfigCompactionEnforceMinThresholdParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCompactionEnforceMinThresholdParams contains all the parameters to send to the API endpoint for the find config compaction enforce min threshold operation typically these are written to a http.Request

func NewFindConfigCompactionEnforceMinThresholdParams ¶

func NewFindConfigCompactionEnforceMinThresholdParams() *FindConfigCompactionEnforceMinThresholdParams

NewFindConfigCompactionEnforceMinThresholdParams creates a new FindConfigCompactionEnforceMinThresholdParams object with the default values initialized.

func NewFindConfigCompactionEnforceMinThresholdParamsWithContext ¶

func NewFindConfigCompactionEnforceMinThresholdParamsWithContext(ctx context.Context) *FindConfigCompactionEnforceMinThresholdParams

NewFindConfigCompactionEnforceMinThresholdParamsWithContext creates a new FindConfigCompactionEnforceMinThresholdParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCompactionEnforceMinThresholdParamsWithHTTPClient ¶

func NewFindConfigCompactionEnforceMinThresholdParamsWithHTTPClient(client *http.Client) *FindConfigCompactionEnforceMinThresholdParams

NewFindConfigCompactionEnforceMinThresholdParamsWithHTTPClient creates a new FindConfigCompactionEnforceMinThresholdParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCompactionEnforceMinThresholdParamsWithTimeout ¶

func NewFindConfigCompactionEnforceMinThresholdParamsWithTimeout(timeout time.Duration) *FindConfigCompactionEnforceMinThresholdParams

NewFindConfigCompactionEnforceMinThresholdParamsWithTimeout creates a new FindConfigCompactionEnforceMinThresholdParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCompactionEnforceMinThresholdParams) SetContext ¶

SetContext adds the context to the find config compaction enforce min threshold params

func (*FindConfigCompactionEnforceMinThresholdParams) SetHTTPClient ¶

func (o *FindConfigCompactionEnforceMinThresholdParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config compaction enforce min threshold params

func (*FindConfigCompactionEnforceMinThresholdParams) SetTimeout ¶

SetTimeout adds the timeout to the find config compaction enforce min threshold params

func (*FindConfigCompactionEnforceMinThresholdParams) WithContext ¶

WithContext adds the context to the find config compaction enforce min threshold params

func (*FindConfigCompactionEnforceMinThresholdParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config compaction enforce min threshold params

func (*FindConfigCompactionEnforceMinThresholdParams) WithTimeout ¶

WithTimeout adds the timeout to the find config compaction enforce min threshold params

func (*FindConfigCompactionEnforceMinThresholdParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCompactionEnforceMinThresholdReader ¶

type FindConfigCompactionEnforceMinThresholdReader struct {
	// contains filtered or unexported fields
}

FindConfigCompactionEnforceMinThresholdReader is a Reader for the FindConfigCompactionEnforceMinThreshold structure.

func (*FindConfigCompactionEnforceMinThresholdReader) ReadResponse ¶

func (o *FindConfigCompactionEnforceMinThresholdReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCompactionLargeCellWarningThresholdMbDefault ¶

type FindConfigCompactionLargeCellWarningThresholdMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCompactionLargeCellWarningThresholdMbDefault handles this case with default header values.

unexpected error

func NewFindConfigCompactionLargeCellWarningThresholdMbDefault ¶

func NewFindConfigCompactionLargeCellWarningThresholdMbDefault(code int) *FindConfigCompactionLargeCellWarningThresholdMbDefault

NewFindConfigCompactionLargeCellWarningThresholdMbDefault creates a FindConfigCompactionLargeCellWarningThresholdMbDefault with default headers values

func (*FindConfigCompactionLargeCellWarningThresholdMbDefault) Code ¶

Code gets the status code for the find config compaction large cell warning threshold mb default response

func (*FindConfigCompactionLargeCellWarningThresholdMbDefault) Error ¶

func (*FindConfigCompactionLargeCellWarningThresholdMbDefault) GetPayload ¶

type FindConfigCompactionLargeCellWarningThresholdMbOK ¶

type FindConfigCompactionLargeCellWarningThresholdMbOK struct {
	Payload int64
}

FindConfigCompactionLargeCellWarningThresholdMbOK handles this case with default header values.

Config value

func NewFindConfigCompactionLargeCellWarningThresholdMbOK ¶

func NewFindConfigCompactionLargeCellWarningThresholdMbOK() *FindConfigCompactionLargeCellWarningThresholdMbOK

NewFindConfigCompactionLargeCellWarningThresholdMbOK creates a FindConfigCompactionLargeCellWarningThresholdMbOK with default headers values

func (*FindConfigCompactionLargeCellWarningThresholdMbOK) GetPayload ¶

type FindConfigCompactionLargeCellWarningThresholdMbParams ¶

type FindConfigCompactionLargeCellWarningThresholdMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCompactionLargeCellWarningThresholdMbParams contains all the parameters to send to the API endpoint for the find config compaction large cell warning threshold mb operation typically these are written to a http.Request

func NewFindConfigCompactionLargeCellWarningThresholdMbParams ¶

func NewFindConfigCompactionLargeCellWarningThresholdMbParams() *FindConfigCompactionLargeCellWarningThresholdMbParams

NewFindConfigCompactionLargeCellWarningThresholdMbParams creates a new FindConfigCompactionLargeCellWarningThresholdMbParams object with the default values initialized.

func NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithContext ¶

func NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithContext(ctx context.Context) *FindConfigCompactionLargeCellWarningThresholdMbParams

NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithContext creates a new FindConfigCompactionLargeCellWarningThresholdMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithHTTPClient ¶

func NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithHTTPClient(client *http.Client) *FindConfigCompactionLargeCellWarningThresholdMbParams

NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithHTTPClient creates a new FindConfigCompactionLargeCellWarningThresholdMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithTimeout ¶

func NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithTimeout(timeout time.Duration) *FindConfigCompactionLargeCellWarningThresholdMbParams

NewFindConfigCompactionLargeCellWarningThresholdMbParamsWithTimeout creates a new FindConfigCompactionLargeCellWarningThresholdMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCompactionLargeCellWarningThresholdMbParams) SetContext ¶

SetContext adds the context to the find config compaction large cell warning threshold mb params

func (*FindConfigCompactionLargeCellWarningThresholdMbParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config compaction large cell warning threshold mb params

func (*FindConfigCompactionLargeCellWarningThresholdMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config compaction large cell warning threshold mb params

func (*FindConfigCompactionLargeCellWarningThresholdMbParams) WithContext ¶

WithContext adds the context to the find config compaction large cell warning threshold mb params

func (*FindConfigCompactionLargeCellWarningThresholdMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config compaction large cell warning threshold mb params

func (*FindConfigCompactionLargeCellWarningThresholdMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config compaction large cell warning threshold mb params

func (*FindConfigCompactionLargeCellWarningThresholdMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCompactionLargeCellWarningThresholdMbReader ¶

type FindConfigCompactionLargeCellWarningThresholdMbReader struct {
	// contains filtered or unexported fields
}

FindConfigCompactionLargeCellWarningThresholdMbReader is a Reader for the FindConfigCompactionLargeCellWarningThresholdMb structure.

func (*FindConfigCompactionLargeCellWarningThresholdMbReader) ReadResponse ¶

func (o *FindConfigCompactionLargeCellWarningThresholdMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCompactionLargePartitionWarningThresholdMbDefault ¶

type FindConfigCompactionLargePartitionWarningThresholdMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCompactionLargePartitionWarningThresholdMbDefault handles this case with default header values.

unexpected error

func NewFindConfigCompactionLargePartitionWarningThresholdMbDefault ¶

func NewFindConfigCompactionLargePartitionWarningThresholdMbDefault(code int) *FindConfigCompactionLargePartitionWarningThresholdMbDefault

NewFindConfigCompactionLargePartitionWarningThresholdMbDefault creates a FindConfigCompactionLargePartitionWarningThresholdMbDefault with default headers values

func (*FindConfigCompactionLargePartitionWarningThresholdMbDefault) Code ¶

Code gets the status code for the find config compaction large partition warning threshold mb default response

func (*FindConfigCompactionLargePartitionWarningThresholdMbDefault) Error ¶

func (*FindConfigCompactionLargePartitionWarningThresholdMbDefault) GetPayload ¶

type FindConfigCompactionLargePartitionWarningThresholdMbOK ¶

type FindConfigCompactionLargePartitionWarningThresholdMbOK struct {
	Payload int64
}

FindConfigCompactionLargePartitionWarningThresholdMbOK handles this case with default header values.

Config value

func NewFindConfigCompactionLargePartitionWarningThresholdMbOK ¶

func NewFindConfigCompactionLargePartitionWarningThresholdMbOK() *FindConfigCompactionLargePartitionWarningThresholdMbOK

NewFindConfigCompactionLargePartitionWarningThresholdMbOK creates a FindConfigCompactionLargePartitionWarningThresholdMbOK with default headers values

func (*FindConfigCompactionLargePartitionWarningThresholdMbOK) GetPayload ¶

type FindConfigCompactionLargePartitionWarningThresholdMbParams ¶

type FindConfigCompactionLargePartitionWarningThresholdMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCompactionLargePartitionWarningThresholdMbParams contains all the parameters to send to the API endpoint for the find config compaction large partition warning threshold mb operation typically these are written to a http.Request

func NewFindConfigCompactionLargePartitionWarningThresholdMbParams ¶

func NewFindConfigCompactionLargePartitionWarningThresholdMbParams() *FindConfigCompactionLargePartitionWarningThresholdMbParams

NewFindConfigCompactionLargePartitionWarningThresholdMbParams creates a new FindConfigCompactionLargePartitionWarningThresholdMbParams object with the default values initialized.

func NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithContext ¶

func NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithContext(ctx context.Context) *FindConfigCompactionLargePartitionWarningThresholdMbParams

NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithContext creates a new FindConfigCompactionLargePartitionWarningThresholdMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithHTTPClient ¶

func NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithHTTPClient(client *http.Client) *FindConfigCompactionLargePartitionWarningThresholdMbParams

NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithHTTPClient creates a new FindConfigCompactionLargePartitionWarningThresholdMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithTimeout ¶

func NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithTimeout(timeout time.Duration) *FindConfigCompactionLargePartitionWarningThresholdMbParams

NewFindConfigCompactionLargePartitionWarningThresholdMbParamsWithTimeout creates a new FindConfigCompactionLargePartitionWarningThresholdMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCompactionLargePartitionWarningThresholdMbParams) SetContext ¶

SetContext adds the context to the find config compaction large partition warning threshold mb params

func (*FindConfigCompactionLargePartitionWarningThresholdMbParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config compaction large partition warning threshold mb params

func (*FindConfigCompactionLargePartitionWarningThresholdMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config compaction large partition warning threshold mb params

func (*FindConfigCompactionLargePartitionWarningThresholdMbParams) WithContext ¶

WithContext adds the context to the find config compaction large partition warning threshold mb params

func (*FindConfigCompactionLargePartitionWarningThresholdMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config compaction large partition warning threshold mb params

func (*FindConfigCompactionLargePartitionWarningThresholdMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config compaction large partition warning threshold mb params

func (*FindConfigCompactionLargePartitionWarningThresholdMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCompactionLargePartitionWarningThresholdMbReader ¶

type FindConfigCompactionLargePartitionWarningThresholdMbReader struct {
	// contains filtered or unexported fields
}

FindConfigCompactionLargePartitionWarningThresholdMbReader is a Reader for the FindConfigCompactionLargePartitionWarningThresholdMb structure.

func (*FindConfigCompactionLargePartitionWarningThresholdMbReader) ReadResponse ¶

ReadResponse reads a server response into the received o.

type FindConfigCompactionLargeRowWarningThresholdMbDefault ¶

type FindConfigCompactionLargeRowWarningThresholdMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCompactionLargeRowWarningThresholdMbDefault handles this case with default header values.

unexpected error

func NewFindConfigCompactionLargeRowWarningThresholdMbDefault ¶

func NewFindConfigCompactionLargeRowWarningThresholdMbDefault(code int) *FindConfigCompactionLargeRowWarningThresholdMbDefault

NewFindConfigCompactionLargeRowWarningThresholdMbDefault creates a FindConfigCompactionLargeRowWarningThresholdMbDefault with default headers values

func (*FindConfigCompactionLargeRowWarningThresholdMbDefault) Code ¶

Code gets the status code for the find config compaction large row warning threshold mb default response

func (*FindConfigCompactionLargeRowWarningThresholdMbDefault) Error ¶

func (*FindConfigCompactionLargeRowWarningThresholdMbDefault) GetPayload ¶

type FindConfigCompactionLargeRowWarningThresholdMbOK ¶

type FindConfigCompactionLargeRowWarningThresholdMbOK struct {
	Payload int64
}

FindConfigCompactionLargeRowWarningThresholdMbOK handles this case with default header values.

Config value

func NewFindConfigCompactionLargeRowWarningThresholdMbOK ¶

func NewFindConfigCompactionLargeRowWarningThresholdMbOK() *FindConfigCompactionLargeRowWarningThresholdMbOK

NewFindConfigCompactionLargeRowWarningThresholdMbOK creates a FindConfigCompactionLargeRowWarningThresholdMbOK with default headers values

func (*FindConfigCompactionLargeRowWarningThresholdMbOK) GetPayload ¶

type FindConfigCompactionLargeRowWarningThresholdMbParams ¶

type FindConfigCompactionLargeRowWarningThresholdMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCompactionLargeRowWarningThresholdMbParams contains all the parameters to send to the API endpoint for the find config compaction large row warning threshold mb operation typically these are written to a http.Request

func NewFindConfigCompactionLargeRowWarningThresholdMbParams ¶

func NewFindConfigCompactionLargeRowWarningThresholdMbParams() *FindConfigCompactionLargeRowWarningThresholdMbParams

NewFindConfigCompactionLargeRowWarningThresholdMbParams creates a new FindConfigCompactionLargeRowWarningThresholdMbParams object with the default values initialized.

func NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithContext ¶

func NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithContext(ctx context.Context) *FindConfigCompactionLargeRowWarningThresholdMbParams

NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithContext creates a new FindConfigCompactionLargeRowWarningThresholdMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithHTTPClient ¶

func NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithHTTPClient(client *http.Client) *FindConfigCompactionLargeRowWarningThresholdMbParams

NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithHTTPClient creates a new FindConfigCompactionLargeRowWarningThresholdMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithTimeout ¶

func NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithTimeout(timeout time.Duration) *FindConfigCompactionLargeRowWarningThresholdMbParams

NewFindConfigCompactionLargeRowWarningThresholdMbParamsWithTimeout creates a new FindConfigCompactionLargeRowWarningThresholdMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCompactionLargeRowWarningThresholdMbParams) SetContext ¶

SetContext adds the context to the find config compaction large row warning threshold mb params

func (*FindConfigCompactionLargeRowWarningThresholdMbParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config compaction large row warning threshold mb params

func (*FindConfigCompactionLargeRowWarningThresholdMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config compaction large row warning threshold mb params

func (*FindConfigCompactionLargeRowWarningThresholdMbParams) WithContext ¶

WithContext adds the context to the find config compaction large row warning threshold mb params

func (*FindConfigCompactionLargeRowWarningThresholdMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config compaction large row warning threshold mb params

func (*FindConfigCompactionLargeRowWarningThresholdMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config compaction large row warning threshold mb params

func (*FindConfigCompactionLargeRowWarningThresholdMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCompactionLargeRowWarningThresholdMbReader ¶

type FindConfigCompactionLargeRowWarningThresholdMbReader struct {
	// contains filtered or unexported fields
}

FindConfigCompactionLargeRowWarningThresholdMbReader is a Reader for the FindConfigCompactionLargeRowWarningThresholdMb structure.

func (*FindConfigCompactionLargeRowWarningThresholdMbReader) ReadResponse ¶

func (o *FindConfigCompactionLargeRowWarningThresholdMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCompactionPreheatKeyCacheDefault ¶

type FindConfigCompactionPreheatKeyCacheDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCompactionPreheatKeyCacheDefault handles this case with default header values.

unexpected error

func NewFindConfigCompactionPreheatKeyCacheDefault ¶

func NewFindConfigCompactionPreheatKeyCacheDefault(code int) *FindConfigCompactionPreheatKeyCacheDefault

NewFindConfigCompactionPreheatKeyCacheDefault creates a FindConfigCompactionPreheatKeyCacheDefault with default headers values

func (*FindConfigCompactionPreheatKeyCacheDefault) Code ¶

Code gets the status code for the find config compaction preheat key cache default response

func (*FindConfigCompactionPreheatKeyCacheDefault) Error ¶

func (*FindConfigCompactionPreheatKeyCacheDefault) GetPayload ¶

type FindConfigCompactionPreheatKeyCacheOK ¶

type FindConfigCompactionPreheatKeyCacheOK struct {
	Payload bool
}

FindConfigCompactionPreheatKeyCacheOK handles this case with default header values.

Config value

func NewFindConfigCompactionPreheatKeyCacheOK ¶

func NewFindConfigCompactionPreheatKeyCacheOK() *FindConfigCompactionPreheatKeyCacheOK

NewFindConfigCompactionPreheatKeyCacheOK creates a FindConfigCompactionPreheatKeyCacheOK with default headers values

func (*FindConfigCompactionPreheatKeyCacheOK) GetPayload ¶

type FindConfigCompactionPreheatKeyCacheParams ¶

type FindConfigCompactionPreheatKeyCacheParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCompactionPreheatKeyCacheParams contains all the parameters to send to the API endpoint for the find config compaction preheat key cache operation typically these are written to a http.Request

func NewFindConfigCompactionPreheatKeyCacheParams ¶

func NewFindConfigCompactionPreheatKeyCacheParams() *FindConfigCompactionPreheatKeyCacheParams

NewFindConfigCompactionPreheatKeyCacheParams creates a new FindConfigCompactionPreheatKeyCacheParams object with the default values initialized.

func NewFindConfigCompactionPreheatKeyCacheParamsWithContext ¶

func NewFindConfigCompactionPreheatKeyCacheParamsWithContext(ctx context.Context) *FindConfigCompactionPreheatKeyCacheParams

NewFindConfigCompactionPreheatKeyCacheParamsWithContext creates a new FindConfigCompactionPreheatKeyCacheParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCompactionPreheatKeyCacheParamsWithHTTPClient ¶

func NewFindConfigCompactionPreheatKeyCacheParamsWithHTTPClient(client *http.Client) *FindConfigCompactionPreheatKeyCacheParams

NewFindConfigCompactionPreheatKeyCacheParamsWithHTTPClient creates a new FindConfigCompactionPreheatKeyCacheParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCompactionPreheatKeyCacheParamsWithTimeout ¶

func NewFindConfigCompactionPreheatKeyCacheParamsWithTimeout(timeout time.Duration) *FindConfigCompactionPreheatKeyCacheParams

NewFindConfigCompactionPreheatKeyCacheParamsWithTimeout creates a new FindConfigCompactionPreheatKeyCacheParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCompactionPreheatKeyCacheParams) SetContext ¶

SetContext adds the context to the find config compaction preheat key cache params

func (*FindConfigCompactionPreheatKeyCacheParams) SetHTTPClient ¶

func (o *FindConfigCompactionPreheatKeyCacheParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config compaction preheat key cache params

func (*FindConfigCompactionPreheatKeyCacheParams) SetTimeout ¶

SetTimeout adds the timeout to the find config compaction preheat key cache params

func (*FindConfigCompactionPreheatKeyCacheParams) WithContext ¶

WithContext adds the context to the find config compaction preheat key cache params

func (*FindConfigCompactionPreheatKeyCacheParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config compaction preheat key cache params

func (*FindConfigCompactionPreheatKeyCacheParams) WithTimeout ¶

WithTimeout adds the timeout to the find config compaction preheat key cache params

func (*FindConfigCompactionPreheatKeyCacheParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCompactionPreheatKeyCacheReader ¶

type FindConfigCompactionPreheatKeyCacheReader struct {
	// contains filtered or unexported fields
}

FindConfigCompactionPreheatKeyCacheReader is a Reader for the FindConfigCompactionPreheatKeyCache structure.

func (*FindConfigCompactionPreheatKeyCacheReader) ReadResponse ¶

func (o *FindConfigCompactionPreheatKeyCacheReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCompactionRowsCountWarningThresholdDefault ¶

type FindConfigCompactionRowsCountWarningThresholdDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCompactionRowsCountWarningThresholdDefault handles this case with default header values.

unexpected error

func NewFindConfigCompactionRowsCountWarningThresholdDefault ¶

func NewFindConfigCompactionRowsCountWarningThresholdDefault(code int) *FindConfigCompactionRowsCountWarningThresholdDefault

NewFindConfigCompactionRowsCountWarningThresholdDefault creates a FindConfigCompactionRowsCountWarningThresholdDefault with default headers values

func (*FindConfigCompactionRowsCountWarningThresholdDefault) Code ¶

Code gets the status code for the find config compaction rows count warning threshold default response

func (*FindConfigCompactionRowsCountWarningThresholdDefault) Error ¶

func (*FindConfigCompactionRowsCountWarningThresholdDefault) GetPayload ¶

type FindConfigCompactionRowsCountWarningThresholdOK ¶

type FindConfigCompactionRowsCountWarningThresholdOK struct {
	Payload int64
}

FindConfigCompactionRowsCountWarningThresholdOK handles this case with default header values.

Config value

func NewFindConfigCompactionRowsCountWarningThresholdOK ¶

func NewFindConfigCompactionRowsCountWarningThresholdOK() *FindConfigCompactionRowsCountWarningThresholdOK

NewFindConfigCompactionRowsCountWarningThresholdOK creates a FindConfigCompactionRowsCountWarningThresholdOK with default headers values

func (*FindConfigCompactionRowsCountWarningThresholdOK) GetPayload ¶

type FindConfigCompactionRowsCountWarningThresholdParams ¶

type FindConfigCompactionRowsCountWarningThresholdParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCompactionRowsCountWarningThresholdParams contains all the parameters to send to the API endpoint for the find config compaction rows count warning threshold operation typically these are written to a http.Request

func NewFindConfigCompactionRowsCountWarningThresholdParams ¶

func NewFindConfigCompactionRowsCountWarningThresholdParams() *FindConfigCompactionRowsCountWarningThresholdParams

NewFindConfigCompactionRowsCountWarningThresholdParams creates a new FindConfigCompactionRowsCountWarningThresholdParams object with the default values initialized.

func NewFindConfigCompactionRowsCountWarningThresholdParamsWithContext ¶

func NewFindConfigCompactionRowsCountWarningThresholdParamsWithContext(ctx context.Context) *FindConfigCompactionRowsCountWarningThresholdParams

NewFindConfigCompactionRowsCountWarningThresholdParamsWithContext creates a new FindConfigCompactionRowsCountWarningThresholdParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCompactionRowsCountWarningThresholdParamsWithHTTPClient ¶

func NewFindConfigCompactionRowsCountWarningThresholdParamsWithHTTPClient(client *http.Client) *FindConfigCompactionRowsCountWarningThresholdParams

NewFindConfigCompactionRowsCountWarningThresholdParamsWithHTTPClient creates a new FindConfigCompactionRowsCountWarningThresholdParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCompactionRowsCountWarningThresholdParamsWithTimeout ¶

func NewFindConfigCompactionRowsCountWarningThresholdParamsWithTimeout(timeout time.Duration) *FindConfigCompactionRowsCountWarningThresholdParams

NewFindConfigCompactionRowsCountWarningThresholdParamsWithTimeout creates a new FindConfigCompactionRowsCountWarningThresholdParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCompactionRowsCountWarningThresholdParams) SetContext ¶

SetContext adds the context to the find config compaction rows count warning threshold params

func (*FindConfigCompactionRowsCountWarningThresholdParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config compaction rows count warning threshold params

func (*FindConfigCompactionRowsCountWarningThresholdParams) SetTimeout ¶

SetTimeout adds the timeout to the find config compaction rows count warning threshold params

func (*FindConfigCompactionRowsCountWarningThresholdParams) WithContext ¶

WithContext adds the context to the find config compaction rows count warning threshold params

func (*FindConfigCompactionRowsCountWarningThresholdParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config compaction rows count warning threshold params

func (*FindConfigCompactionRowsCountWarningThresholdParams) WithTimeout ¶

WithTimeout adds the timeout to the find config compaction rows count warning threshold params

func (*FindConfigCompactionRowsCountWarningThresholdParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCompactionRowsCountWarningThresholdReader ¶

type FindConfigCompactionRowsCountWarningThresholdReader struct {
	// contains filtered or unexported fields
}

FindConfigCompactionRowsCountWarningThresholdReader is a Reader for the FindConfigCompactionRowsCountWarningThreshold structure.

func (*FindConfigCompactionRowsCountWarningThresholdReader) ReadResponse ¶

func (o *FindConfigCompactionRowsCountWarningThresholdReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCompactionStaticSharesDefault ¶

type FindConfigCompactionStaticSharesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCompactionStaticSharesDefault handles this case with default header values.

unexpected error

func NewFindConfigCompactionStaticSharesDefault ¶

func NewFindConfigCompactionStaticSharesDefault(code int) *FindConfigCompactionStaticSharesDefault

NewFindConfigCompactionStaticSharesDefault creates a FindConfigCompactionStaticSharesDefault with default headers values

func (*FindConfigCompactionStaticSharesDefault) Code ¶

Code gets the status code for the find config compaction static shares default response

func (*FindConfigCompactionStaticSharesDefault) Error ¶

func (*FindConfigCompactionStaticSharesDefault) GetPayload ¶

type FindConfigCompactionStaticSharesOK ¶

type FindConfigCompactionStaticSharesOK struct {
	Payload float64
}

FindConfigCompactionStaticSharesOK handles this case with default header values.

Config value

func NewFindConfigCompactionStaticSharesOK ¶

func NewFindConfigCompactionStaticSharesOK() *FindConfigCompactionStaticSharesOK

NewFindConfigCompactionStaticSharesOK creates a FindConfigCompactionStaticSharesOK with default headers values

func (*FindConfigCompactionStaticSharesOK) GetPayload ¶

type FindConfigCompactionStaticSharesParams ¶

type FindConfigCompactionStaticSharesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCompactionStaticSharesParams contains all the parameters to send to the API endpoint for the find config compaction static shares operation typically these are written to a http.Request

func NewFindConfigCompactionStaticSharesParams ¶

func NewFindConfigCompactionStaticSharesParams() *FindConfigCompactionStaticSharesParams

NewFindConfigCompactionStaticSharesParams creates a new FindConfigCompactionStaticSharesParams object with the default values initialized.

func NewFindConfigCompactionStaticSharesParamsWithContext ¶

func NewFindConfigCompactionStaticSharesParamsWithContext(ctx context.Context) *FindConfigCompactionStaticSharesParams

NewFindConfigCompactionStaticSharesParamsWithContext creates a new FindConfigCompactionStaticSharesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCompactionStaticSharesParamsWithHTTPClient ¶

func NewFindConfigCompactionStaticSharesParamsWithHTTPClient(client *http.Client) *FindConfigCompactionStaticSharesParams

NewFindConfigCompactionStaticSharesParamsWithHTTPClient creates a new FindConfigCompactionStaticSharesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCompactionStaticSharesParamsWithTimeout ¶

func NewFindConfigCompactionStaticSharesParamsWithTimeout(timeout time.Duration) *FindConfigCompactionStaticSharesParams

NewFindConfigCompactionStaticSharesParamsWithTimeout creates a new FindConfigCompactionStaticSharesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCompactionStaticSharesParams) SetContext ¶

SetContext adds the context to the find config compaction static shares params

func (*FindConfigCompactionStaticSharesParams) SetHTTPClient ¶

func (o *FindConfigCompactionStaticSharesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config compaction static shares params

func (*FindConfigCompactionStaticSharesParams) SetTimeout ¶

func (o *FindConfigCompactionStaticSharesParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config compaction static shares params

func (*FindConfigCompactionStaticSharesParams) WithContext ¶

WithContext adds the context to the find config compaction static shares params

func (*FindConfigCompactionStaticSharesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config compaction static shares params

func (*FindConfigCompactionStaticSharesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config compaction static shares params

func (*FindConfigCompactionStaticSharesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCompactionStaticSharesReader ¶

type FindConfigCompactionStaticSharesReader struct {
	// contains filtered or unexported fields
}

FindConfigCompactionStaticSharesReader is a Reader for the FindConfigCompactionStaticShares structure.

func (*FindConfigCompactionStaticSharesReader) ReadResponse ¶

func (o *FindConfigCompactionStaticSharesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCompactionThroughputMbPerSecDefault ¶

type FindConfigCompactionThroughputMbPerSecDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCompactionThroughputMbPerSecDefault handles this case with default header values.

unexpected error

func NewFindConfigCompactionThroughputMbPerSecDefault ¶

func NewFindConfigCompactionThroughputMbPerSecDefault(code int) *FindConfigCompactionThroughputMbPerSecDefault

NewFindConfigCompactionThroughputMbPerSecDefault creates a FindConfigCompactionThroughputMbPerSecDefault with default headers values

func (*FindConfigCompactionThroughputMbPerSecDefault) Code ¶

Code gets the status code for the find config compaction throughput mb per sec default response

func (*FindConfigCompactionThroughputMbPerSecDefault) Error ¶

func (*FindConfigCompactionThroughputMbPerSecDefault) GetPayload ¶

type FindConfigCompactionThroughputMbPerSecOK ¶

type FindConfigCompactionThroughputMbPerSecOK struct {
	Payload int64
}

FindConfigCompactionThroughputMbPerSecOK handles this case with default header values.

Config value

func NewFindConfigCompactionThroughputMbPerSecOK ¶

func NewFindConfigCompactionThroughputMbPerSecOK() *FindConfigCompactionThroughputMbPerSecOK

NewFindConfigCompactionThroughputMbPerSecOK creates a FindConfigCompactionThroughputMbPerSecOK with default headers values

func (*FindConfigCompactionThroughputMbPerSecOK) GetPayload ¶

type FindConfigCompactionThroughputMbPerSecParams ¶

type FindConfigCompactionThroughputMbPerSecParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCompactionThroughputMbPerSecParams contains all the parameters to send to the API endpoint for the find config compaction throughput mb per sec operation typically these are written to a http.Request

func NewFindConfigCompactionThroughputMbPerSecParams ¶

func NewFindConfigCompactionThroughputMbPerSecParams() *FindConfigCompactionThroughputMbPerSecParams

NewFindConfigCompactionThroughputMbPerSecParams creates a new FindConfigCompactionThroughputMbPerSecParams object with the default values initialized.

func NewFindConfigCompactionThroughputMbPerSecParamsWithContext ¶

func NewFindConfigCompactionThroughputMbPerSecParamsWithContext(ctx context.Context) *FindConfigCompactionThroughputMbPerSecParams

NewFindConfigCompactionThroughputMbPerSecParamsWithContext creates a new FindConfigCompactionThroughputMbPerSecParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCompactionThroughputMbPerSecParamsWithHTTPClient ¶

func NewFindConfigCompactionThroughputMbPerSecParamsWithHTTPClient(client *http.Client) *FindConfigCompactionThroughputMbPerSecParams

NewFindConfigCompactionThroughputMbPerSecParamsWithHTTPClient creates a new FindConfigCompactionThroughputMbPerSecParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCompactionThroughputMbPerSecParamsWithTimeout ¶

func NewFindConfigCompactionThroughputMbPerSecParamsWithTimeout(timeout time.Duration) *FindConfigCompactionThroughputMbPerSecParams

NewFindConfigCompactionThroughputMbPerSecParamsWithTimeout creates a new FindConfigCompactionThroughputMbPerSecParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCompactionThroughputMbPerSecParams) SetContext ¶

SetContext adds the context to the find config compaction throughput mb per sec params

func (*FindConfigCompactionThroughputMbPerSecParams) SetHTTPClient ¶

func (o *FindConfigCompactionThroughputMbPerSecParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config compaction throughput mb per sec params

func (*FindConfigCompactionThroughputMbPerSecParams) SetTimeout ¶

SetTimeout adds the timeout to the find config compaction throughput mb per sec params

func (*FindConfigCompactionThroughputMbPerSecParams) WithContext ¶

WithContext adds the context to the find config compaction throughput mb per sec params

func (*FindConfigCompactionThroughputMbPerSecParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config compaction throughput mb per sec params

func (*FindConfigCompactionThroughputMbPerSecParams) WithTimeout ¶

WithTimeout adds the timeout to the find config compaction throughput mb per sec params

func (*FindConfigCompactionThroughputMbPerSecParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCompactionThroughputMbPerSecReader ¶

type FindConfigCompactionThroughputMbPerSecReader struct {
	// contains filtered or unexported fields
}

FindConfigCompactionThroughputMbPerSecReader is a Reader for the FindConfigCompactionThroughputMbPerSec structure.

func (*FindConfigCompactionThroughputMbPerSecReader) ReadResponse ¶

func (o *FindConfigCompactionThroughputMbPerSecReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigConcurrentCompactorsDefault ¶

type FindConfigConcurrentCompactorsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigConcurrentCompactorsDefault handles this case with default header values.

unexpected error

func NewFindConfigConcurrentCompactorsDefault ¶

func NewFindConfigConcurrentCompactorsDefault(code int) *FindConfigConcurrentCompactorsDefault

NewFindConfigConcurrentCompactorsDefault creates a FindConfigConcurrentCompactorsDefault with default headers values

func (*FindConfigConcurrentCompactorsDefault) Code ¶

Code gets the status code for the find config concurrent compactors default response

func (*FindConfigConcurrentCompactorsDefault) Error ¶

func (*FindConfigConcurrentCompactorsDefault) GetPayload ¶

type FindConfigConcurrentCompactorsOK ¶

type FindConfigConcurrentCompactorsOK struct {
	Payload int64
}

FindConfigConcurrentCompactorsOK handles this case with default header values.

Config value

func NewFindConfigConcurrentCompactorsOK ¶

func NewFindConfigConcurrentCompactorsOK() *FindConfigConcurrentCompactorsOK

NewFindConfigConcurrentCompactorsOK creates a FindConfigConcurrentCompactorsOK with default headers values

func (*FindConfigConcurrentCompactorsOK) GetPayload ¶

func (o *FindConfigConcurrentCompactorsOK) GetPayload() int64

type FindConfigConcurrentCompactorsParams ¶

type FindConfigConcurrentCompactorsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigConcurrentCompactorsParams contains all the parameters to send to the API endpoint for the find config concurrent compactors operation typically these are written to a http.Request

func NewFindConfigConcurrentCompactorsParams ¶

func NewFindConfigConcurrentCompactorsParams() *FindConfigConcurrentCompactorsParams

NewFindConfigConcurrentCompactorsParams creates a new FindConfigConcurrentCompactorsParams object with the default values initialized.

func NewFindConfigConcurrentCompactorsParamsWithContext ¶

func NewFindConfigConcurrentCompactorsParamsWithContext(ctx context.Context) *FindConfigConcurrentCompactorsParams

NewFindConfigConcurrentCompactorsParamsWithContext creates a new FindConfigConcurrentCompactorsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigConcurrentCompactorsParamsWithHTTPClient ¶

func NewFindConfigConcurrentCompactorsParamsWithHTTPClient(client *http.Client) *FindConfigConcurrentCompactorsParams

NewFindConfigConcurrentCompactorsParamsWithHTTPClient creates a new FindConfigConcurrentCompactorsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigConcurrentCompactorsParamsWithTimeout ¶

func NewFindConfigConcurrentCompactorsParamsWithTimeout(timeout time.Duration) *FindConfigConcurrentCompactorsParams

NewFindConfigConcurrentCompactorsParamsWithTimeout creates a new FindConfigConcurrentCompactorsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigConcurrentCompactorsParams) SetContext ¶

SetContext adds the context to the find config concurrent compactors params

func (*FindConfigConcurrentCompactorsParams) SetHTTPClient ¶

func (o *FindConfigConcurrentCompactorsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config concurrent compactors params

func (*FindConfigConcurrentCompactorsParams) SetTimeout ¶

func (o *FindConfigConcurrentCompactorsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config concurrent compactors params

func (*FindConfigConcurrentCompactorsParams) WithContext ¶

WithContext adds the context to the find config concurrent compactors params

func (*FindConfigConcurrentCompactorsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config concurrent compactors params

func (*FindConfigConcurrentCompactorsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config concurrent compactors params

func (*FindConfigConcurrentCompactorsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigConcurrentCompactorsReader ¶

type FindConfigConcurrentCompactorsReader struct {
	// contains filtered or unexported fields
}

FindConfigConcurrentCompactorsReader is a Reader for the FindConfigConcurrentCompactors structure.

func (*FindConfigConcurrentCompactorsReader) ReadResponse ¶

func (o *FindConfigConcurrentCompactorsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigConcurrentCounterWritesDefault ¶

type FindConfigConcurrentCounterWritesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigConcurrentCounterWritesDefault handles this case with default header values.

unexpected error

func NewFindConfigConcurrentCounterWritesDefault ¶

func NewFindConfigConcurrentCounterWritesDefault(code int) *FindConfigConcurrentCounterWritesDefault

NewFindConfigConcurrentCounterWritesDefault creates a FindConfigConcurrentCounterWritesDefault with default headers values

func (*FindConfigConcurrentCounterWritesDefault) Code ¶

Code gets the status code for the find config concurrent counter writes default response

func (*FindConfigConcurrentCounterWritesDefault) Error ¶

func (*FindConfigConcurrentCounterWritesDefault) GetPayload ¶

type FindConfigConcurrentCounterWritesOK ¶

type FindConfigConcurrentCounterWritesOK struct {
	Payload int64
}

FindConfigConcurrentCounterWritesOK handles this case with default header values.

Config value

func NewFindConfigConcurrentCounterWritesOK ¶

func NewFindConfigConcurrentCounterWritesOK() *FindConfigConcurrentCounterWritesOK

NewFindConfigConcurrentCounterWritesOK creates a FindConfigConcurrentCounterWritesOK with default headers values

func (*FindConfigConcurrentCounterWritesOK) GetPayload ¶

type FindConfigConcurrentCounterWritesParams ¶

type FindConfigConcurrentCounterWritesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigConcurrentCounterWritesParams contains all the parameters to send to the API endpoint for the find config concurrent counter writes operation typically these are written to a http.Request

func NewFindConfigConcurrentCounterWritesParams ¶

func NewFindConfigConcurrentCounterWritesParams() *FindConfigConcurrentCounterWritesParams

NewFindConfigConcurrentCounterWritesParams creates a new FindConfigConcurrentCounterWritesParams object with the default values initialized.

func NewFindConfigConcurrentCounterWritesParamsWithContext ¶

func NewFindConfigConcurrentCounterWritesParamsWithContext(ctx context.Context) *FindConfigConcurrentCounterWritesParams

NewFindConfigConcurrentCounterWritesParamsWithContext creates a new FindConfigConcurrentCounterWritesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigConcurrentCounterWritesParamsWithHTTPClient ¶

func NewFindConfigConcurrentCounterWritesParamsWithHTTPClient(client *http.Client) *FindConfigConcurrentCounterWritesParams

NewFindConfigConcurrentCounterWritesParamsWithHTTPClient creates a new FindConfigConcurrentCounterWritesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigConcurrentCounterWritesParamsWithTimeout ¶

func NewFindConfigConcurrentCounterWritesParamsWithTimeout(timeout time.Duration) *FindConfigConcurrentCounterWritesParams

NewFindConfigConcurrentCounterWritesParamsWithTimeout creates a new FindConfigConcurrentCounterWritesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigConcurrentCounterWritesParams) SetContext ¶

SetContext adds the context to the find config concurrent counter writes params

func (*FindConfigConcurrentCounterWritesParams) SetHTTPClient ¶

func (o *FindConfigConcurrentCounterWritesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config concurrent counter writes params

func (*FindConfigConcurrentCounterWritesParams) SetTimeout ¶

func (o *FindConfigConcurrentCounterWritesParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config concurrent counter writes params

func (*FindConfigConcurrentCounterWritesParams) WithContext ¶

WithContext adds the context to the find config concurrent counter writes params

func (*FindConfigConcurrentCounterWritesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config concurrent counter writes params

func (*FindConfigConcurrentCounterWritesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config concurrent counter writes params

func (*FindConfigConcurrentCounterWritesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigConcurrentCounterWritesReader ¶

type FindConfigConcurrentCounterWritesReader struct {
	// contains filtered or unexported fields
}

FindConfigConcurrentCounterWritesReader is a Reader for the FindConfigConcurrentCounterWrites structure.

func (*FindConfigConcurrentCounterWritesReader) ReadResponse ¶

func (o *FindConfigConcurrentCounterWritesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigConcurrentReadsDefault ¶

type FindConfigConcurrentReadsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigConcurrentReadsDefault handles this case with default header values.

unexpected error

func NewFindConfigConcurrentReadsDefault ¶

func NewFindConfigConcurrentReadsDefault(code int) *FindConfigConcurrentReadsDefault

NewFindConfigConcurrentReadsDefault creates a FindConfigConcurrentReadsDefault with default headers values

func (*FindConfigConcurrentReadsDefault) Code ¶

Code gets the status code for the find config concurrent reads default response

func (*FindConfigConcurrentReadsDefault) Error ¶

func (*FindConfigConcurrentReadsDefault) GetPayload ¶

type FindConfigConcurrentReadsOK ¶

type FindConfigConcurrentReadsOK struct {
	Payload int64
}

FindConfigConcurrentReadsOK handles this case with default header values.

Config value

func NewFindConfigConcurrentReadsOK ¶

func NewFindConfigConcurrentReadsOK() *FindConfigConcurrentReadsOK

NewFindConfigConcurrentReadsOK creates a FindConfigConcurrentReadsOK with default headers values

func (*FindConfigConcurrentReadsOK) GetPayload ¶

func (o *FindConfigConcurrentReadsOK) GetPayload() int64

type FindConfigConcurrentReadsParams ¶

type FindConfigConcurrentReadsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigConcurrentReadsParams contains all the parameters to send to the API endpoint for the find config concurrent reads operation typically these are written to a http.Request

func NewFindConfigConcurrentReadsParams ¶

func NewFindConfigConcurrentReadsParams() *FindConfigConcurrentReadsParams

NewFindConfigConcurrentReadsParams creates a new FindConfigConcurrentReadsParams object with the default values initialized.

func NewFindConfigConcurrentReadsParamsWithContext ¶

func NewFindConfigConcurrentReadsParamsWithContext(ctx context.Context) *FindConfigConcurrentReadsParams

NewFindConfigConcurrentReadsParamsWithContext creates a new FindConfigConcurrentReadsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigConcurrentReadsParamsWithHTTPClient ¶

func NewFindConfigConcurrentReadsParamsWithHTTPClient(client *http.Client) *FindConfigConcurrentReadsParams

NewFindConfigConcurrentReadsParamsWithHTTPClient creates a new FindConfigConcurrentReadsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigConcurrentReadsParamsWithTimeout ¶

func NewFindConfigConcurrentReadsParamsWithTimeout(timeout time.Duration) *FindConfigConcurrentReadsParams

NewFindConfigConcurrentReadsParamsWithTimeout creates a new FindConfigConcurrentReadsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigConcurrentReadsParams) SetContext ¶

func (o *FindConfigConcurrentReadsParams) SetContext(ctx context.Context)

SetContext adds the context to the find config concurrent reads params

func (*FindConfigConcurrentReadsParams) SetHTTPClient ¶

func (o *FindConfigConcurrentReadsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config concurrent reads params

func (*FindConfigConcurrentReadsParams) SetTimeout ¶

func (o *FindConfigConcurrentReadsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config concurrent reads params

func (*FindConfigConcurrentReadsParams) WithContext ¶

WithContext adds the context to the find config concurrent reads params

func (*FindConfigConcurrentReadsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config concurrent reads params

func (*FindConfigConcurrentReadsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config concurrent reads params

func (*FindConfigConcurrentReadsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigConcurrentReadsReader ¶

type FindConfigConcurrentReadsReader struct {
	// contains filtered or unexported fields
}

FindConfigConcurrentReadsReader is a Reader for the FindConfigConcurrentReads structure.

func (*FindConfigConcurrentReadsReader) ReadResponse ¶

func (o *FindConfigConcurrentReadsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigConcurrentWritesDefault ¶

type FindConfigConcurrentWritesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigConcurrentWritesDefault handles this case with default header values.

unexpected error

func NewFindConfigConcurrentWritesDefault ¶

func NewFindConfigConcurrentWritesDefault(code int) *FindConfigConcurrentWritesDefault

NewFindConfigConcurrentWritesDefault creates a FindConfigConcurrentWritesDefault with default headers values

func (*FindConfigConcurrentWritesDefault) Code ¶

Code gets the status code for the find config concurrent writes default response

func (*FindConfigConcurrentWritesDefault) Error ¶

func (*FindConfigConcurrentWritesDefault) GetPayload ¶

type FindConfigConcurrentWritesOK ¶

type FindConfigConcurrentWritesOK struct {
	Payload int64
}

FindConfigConcurrentWritesOK handles this case with default header values.

Config value

func NewFindConfigConcurrentWritesOK ¶

func NewFindConfigConcurrentWritesOK() *FindConfigConcurrentWritesOK

NewFindConfigConcurrentWritesOK creates a FindConfigConcurrentWritesOK with default headers values

func (*FindConfigConcurrentWritesOK) GetPayload ¶

func (o *FindConfigConcurrentWritesOK) GetPayload() int64

type FindConfigConcurrentWritesParams ¶

type FindConfigConcurrentWritesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigConcurrentWritesParams contains all the parameters to send to the API endpoint for the find config concurrent writes operation typically these are written to a http.Request

func NewFindConfigConcurrentWritesParams ¶

func NewFindConfigConcurrentWritesParams() *FindConfigConcurrentWritesParams

NewFindConfigConcurrentWritesParams creates a new FindConfigConcurrentWritesParams object with the default values initialized.

func NewFindConfigConcurrentWritesParamsWithContext ¶

func NewFindConfigConcurrentWritesParamsWithContext(ctx context.Context) *FindConfigConcurrentWritesParams

NewFindConfigConcurrentWritesParamsWithContext creates a new FindConfigConcurrentWritesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigConcurrentWritesParamsWithHTTPClient ¶

func NewFindConfigConcurrentWritesParamsWithHTTPClient(client *http.Client) *FindConfigConcurrentWritesParams

NewFindConfigConcurrentWritesParamsWithHTTPClient creates a new FindConfigConcurrentWritesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigConcurrentWritesParamsWithTimeout ¶

func NewFindConfigConcurrentWritesParamsWithTimeout(timeout time.Duration) *FindConfigConcurrentWritesParams

NewFindConfigConcurrentWritesParamsWithTimeout creates a new FindConfigConcurrentWritesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigConcurrentWritesParams) SetContext ¶

SetContext adds the context to the find config concurrent writes params

func (*FindConfigConcurrentWritesParams) SetHTTPClient ¶

func (o *FindConfigConcurrentWritesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config concurrent writes params

func (*FindConfigConcurrentWritesParams) SetTimeout ¶

func (o *FindConfigConcurrentWritesParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config concurrent writes params

func (*FindConfigConcurrentWritesParams) WithContext ¶

WithContext adds the context to the find config concurrent writes params

func (*FindConfigConcurrentWritesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config concurrent writes params

func (*FindConfigConcurrentWritesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config concurrent writes params

func (*FindConfigConcurrentWritesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigConcurrentWritesReader ¶

type FindConfigConcurrentWritesReader struct {
	// contains filtered or unexported fields
}

FindConfigConcurrentWritesReader is a Reader for the FindConfigConcurrentWrites structure.

func (*FindConfigConcurrentWritesReader) ReadResponse ¶

func (o *FindConfigConcurrentWritesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigConsistentRangemovementDefault ¶

type FindConfigConsistentRangemovementDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigConsistentRangemovementDefault handles this case with default header values.

unexpected error

func NewFindConfigConsistentRangemovementDefault ¶

func NewFindConfigConsistentRangemovementDefault(code int) *FindConfigConsistentRangemovementDefault

NewFindConfigConsistentRangemovementDefault creates a FindConfigConsistentRangemovementDefault with default headers values

func (*FindConfigConsistentRangemovementDefault) Code ¶

Code gets the status code for the find config consistent rangemovement default response

func (*FindConfigConsistentRangemovementDefault) Error ¶

func (*FindConfigConsistentRangemovementDefault) GetPayload ¶

type FindConfigConsistentRangemovementOK ¶

type FindConfigConsistentRangemovementOK struct {
	Payload bool
}

FindConfigConsistentRangemovementOK handles this case with default header values.

Config value

func NewFindConfigConsistentRangemovementOK ¶

func NewFindConfigConsistentRangemovementOK() *FindConfigConsistentRangemovementOK

NewFindConfigConsistentRangemovementOK creates a FindConfigConsistentRangemovementOK with default headers values

func (*FindConfigConsistentRangemovementOK) GetPayload ¶

func (o *FindConfigConsistentRangemovementOK) GetPayload() bool

type FindConfigConsistentRangemovementParams ¶

type FindConfigConsistentRangemovementParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigConsistentRangemovementParams contains all the parameters to send to the API endpoint for the find config consistent rangemovement operation typically these are written to a http.Request

func NewFindConfigConsistentRangemovementParams ¶

func NewFindConfigConsistentRangemovementParams() *FindConfigConsistentRangemovementParams

NewFindConfigConsistentRangemovementParams creates a new FindConfigConsistentRangemovementParams object with the default values initialized.

func NewFindConfigConsistentRangemovementParamsWithContext ¶

func NewFindConfigConsistentRangemovementParamsWithContext(ctx context.Context) *FindConfigConsistentRangemovementParams

NewFindConfigConsistentRangemovementParamsWithContext creates a new FindConfigConsistentRangemovementParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigConsistentRangemovementParamsWithHTTPClient ¶

func NewFindConfigConsistentRangemovementParamsWithHTTPClient(client *http.Client) *FindConfigConsistentRangemovementParams

NewFindConfigConsistentRangemovementParamsWithHTTPClient creates a new FindConfigConsistentRangemovementParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigConsistentRangemovementParamsWithTimeout ¶

func NewFindConfigConsistentRangemovementParamsWithTimeout(timeout time.Duration) *FindConfigConsistentRangemovementParams

NewFindConfigConsistentRangemovementParamsWithTimeout creates a new FindConfigConsistentRangemovementParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigConsistentRangemovementParams) SetContext ¶

SetContext adds the context to the find config consistent rangemovement params

func (*FindConfigConsistentRangemovementParams) SetHTTPClient ¶

func (o *FindConfigConsistentRangemovementParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config consistent rangemovement params

func (*FindConfigConsistentRangemovementParams) SetTimeout ¶

func (o *FindConfigConsistentRangemovementParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config consistent rangemovement params

func (*FindConfigConsistentRangemovementParams) WithContext ¶

WithContext adds the context to the find config consistent rangemovement params

func (*FindConfigConsistentRangemovementParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config consistent rangemovement params

func (*FindConfigConsistentRangemovementParams) WithTimeout ¶

WithTimeout adds the timeout to the find config consistent rangemovement params

func (*FindConfigConsistentRangemovementParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigConsistentRangemovementReader ¶

type FindConfigConsistentRangemovementReader struct {
	// contains filtered or unexported fields
}

FindConfigConsistentRangemovementReader is a Reader for the FindConfigConsistentRangemovement structure.

func (*FindConfigConsistentRangemovementReader) ReadResponse ¶

func (o *FindConfigConsistentRangemovementReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCounterCacheKeysToSaveDefault ¶

type FindConfigCounterCacheKeysToSaveDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCounterCacheKeysToSaveDefault handles this case with default header values.

unexpected error

func NewFindConfigCounterCacheKeysToSaveDefault ¶

func NewFindConfigCounterCacheKeysToSaveDefault(code int) *FindConfigCounterCacheKeysToSaveDefault

NewFindConfigCounterCacheKeysToSaveDefault creates a FindConfigCounterCacheKeysToSaveDefault with default headers values

func (*FindConfigCounterCacheKeysToSaveDefault) Code ¶

Code gets the status code for the find config counter cache keys to save default response

func (*FindConfigCounterCacheKeysToSaveDefault) Error ¶

func (*FindConfigCounterCacheKeysToSaveDefault) GetPayload ¶

type FindConfigCounterCacheKeysToSaveOK ¶

type FindConfigCounterCacheKeysToSaveOK struct {
	Payload int64
}

FindConfigCounterCacheKeysToSaveOK handles this case with default header values.

Config value

func NewFindConfigCounterCacheKeysToSaveOK ¶

func NewFindConfigCounterCacheKeysToSaveOK() *FindConfigCounterCacheKeysToSaveOK

NewFindConfigCounterCacheKeysToSaveOK creates a FindConfigCounterCacheKeysToSaveOK with default headers values

func (*FindConfigCounterCacheKeysToSaveOK) GetPayload ¶

func (o *FindConfigCounterCacheKeysToSaveOK) GetPayload() int64

type FindConfigCounterCacheKeysToSaveParams ¶

type FindConfigCounterCacheKeysToSaveParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCounterCacheKeysToSaveParams contains all the parameters to send to the API endpoint for the find config counter cache keys to save operation typically these are written to a http.Request

func NewFindConfigCounterCacheKeysToSaveParams ¶

func NewFindConfigCounterCacheKeysToSaveParams() *FindConfigCounterCacheKeysToSaveParams

NewFindConfigCounterCacheKeysToSaveParams creates a new FindConfigCounterCacheKeysToSaveParams object with the default values initialized.

func NewFindConfigCounterCacheKeysToSaveParamsWithContext ¶

func NewFindConfigCounterCacheKeysToSaveParamsWithContext(ctx context.Context) *FindConfigCounterCacheKeysToSaveParams

NewFindConfigCounterCacheKeysToSaveParamsWithContext creates a new FindConfigCounterCacheKeysToSaveParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCounterCacheKeysToSaveParamsWithHTTPClient ¶

func NewFindConfigCounterCacheKeysToSaveParamsWithHTTPClient(client *http.Client) *FindConfigCounterCacheKeysToSaveParams

NewFindConfigCounterCacheKeysToSaveParamsWithHTTPClient creates a new FindConfigCounterCacheKeysToSaveParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCounterCacheKeysToSaveParamsWithTimeout ¶

func NewFindConfigCounterCacheKeysToSaveParamsWithTimeout(timeout time.Duration) *FindConfigCounterCacheKeysToSaveParams

NewFindConfigCounterCacheKeysToSaveParamsWithTimeout creates a new FindConfigCounterCacheKeysToSaveParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCounterCacheKeysToSaveParams) SetContext ¶

SetContext adds the context to the find config counter cache keys to save params

func (*FindConfigCounterCacheKeysToSaveParams) SetHTTPClient ¶

func (o *FindConfigCounterCacheKeysToSaveParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config counter cache keys to save params

func (*FindConfigCounterCacheKeysToSaveParams) SetTimeout ¶

func (o *FindConfigCounterCacheKeysToSaveParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config counter cache keys to save params

func (*FindConfigCounterCacheKeysToSaveParams) WithContext ¶

WithContext adds the context to the find config counter cache keys to save params

func (*FindConfigCounterCacheKeysToSaveParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config counter cache keys to save params

func (*FindConfigCounterCacheKeysToSaveParams) WithTimeout ¶

WithTimeout adds the timeout to the find config counter cache keys to save params

func (*FindConfigCounterCacheKeysToSaveParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCounterCacheKeysToSaveReader ¶

type FindConfigCounterCacheKeysToSaveReader struct {
	// contains filtered or unexported fields
}

FindConfigCounterCacheKeysToSaveReader is a Reader for the FindConfigCounterCacheKeysToSave structure.

func (*FindConfigCounterCacheKeysToSaveReader) ReadResponse ¶

func (o *FindConfigCounterCacheKeysToSaveReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCounterCacheSavePeriodDefault ¶

type FindConfigCounterCacheSavePeriodDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCounterCacheSavePeriodDefault handles this case with default header values.

unexpected error

func NewFindConfigCounterCacheSavePeriodDefault ¶

func NewFindConfigCounterCacheSavePeriodDefault(code int) *FindConfigCounterCacheSavePeriodDefault

NewFindConfigCounterCacheSavePeriodDefault creates a FindConfigCounterCacheSavePeriodDefault with default headers values

func (*FindConfigCounterCacheSavePeriodDefault) Code ¶

Code gets the status code for the find config counter cache save period default response

func (*FindConfigCounterCacheSavePeriodDefault) Error ¶

func (*FindConfigCounterCacheSavePeriodDefault) GetPayload ¶

type FindConfigCounterCacheSavePeriodOK ¶

type FindConfigCounterCacheSavePeriodOK struct {
	Payload int64
}

FindConfigCounterCacheSavePeriodOK handles this case with default header values.

Config value

func NewFindConfigCounterCacheSavePeriodOK ¶

func NewFindConfigCounterCacheSavePeriodOK() *FindConfigCounterCacheSavePeriodOK

NewFindConfigCounterCacheSavePeriodOK creates a FindConfigCounterCacheSavePeriodOK with default headers values

func (*FindConfigCounterCacheSavePeriodOK) GetPayload ¶

func (o *FindConfigCounterCacheSavePeriodOK) GetPayload() int64

type FindConfigCounterCacheSavePeriodParams ¶

type FindConfigCounterCacheSavePeriodParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCounterCacheSavePeriodParams contains all the parameters to send to the API endpoint for the find config counter cache save period operation typically these are written to a http.Request

func NewFindConfigCounterCacheSavePeriodParams ¶

func NewFindConfigCounterCacheSavePeriodParams() *FindConfigCounterCacheSavePeriodParams

NewFindConfigCounterCacheSavePeriodParams creates a new FindConfigCounterCacheSavePeriodParams object with the default values initialized.

func NewFindConfigCounterCacheSavePeriodParamsWithContext ¶

func NewFindConfigCounterCacheSavePeriodParamsWithContext(ctx context.Context) *FindConfigCounterCacheSavePeriodParams

NewFindConfigCounterCacheSavePeriodParamsWithContext creates a new FindConfigCounterCacheSavePeriodParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCounterCacheSavePeriodParamsWithHTTPClient ¶

func NewFindConfigCounterCacheSavePeriodParamsWithHTTPClient(client *http.Client) *FindConfigCounterCacheSavePeriodParams

NewFindConfigCounterCacheSavePeriodParamsWithHTTPClient creates a new FindConfigCounterCacheSavePeriodParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCounterCacheSavePeriodParamsWithTimeout ¶

func NewFindConfigCounterCacheSavePeriodParamsWithTimeout(timeout time.Duration) *FindConfigCounterCacheSavePeriodParams

NewFindConfigCounterCacheSavePeriodParamsWithTimeout creates a new FindConfigCounterCacheSavePeriodParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCounterCacheSavePeriodParams) SetContext ¶

SetContext adds the context to the find config counter cache save period params

func (*FindConfigCounterCacheSavePeriodParams) SetHTTPClient ¶

func (o *FindConfigCounterCacheSavePeriodParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config counter cache save period params

func (*FindConfigCounterCacheSavePeriodParams) SetTimeout ¶

func (o *FindConfigCounterCacheSavePeriodParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config counter cache save period params

func (*FindConfigCounterCacheSavePeriodParams) WithContext ¶

WithContext adds the context to the find config counter cache save period params

func (*FindConfigCounterCacheSavePeriodParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config counter cache save period params

func (*FindConfigCounterCacheSavePeriodParams) WithTimeout ¶

WithTimeout adds the timeout to the find config counter cache save period params

func (*FindConfigCounterCacheSavePeriodParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCounterCacheSavePeriodReader ¶

type FindConfigCounterCacheSavePeriodReader struct {
	// contains filtered or unexported fields
}

FindConfigCounterCacheSavePeriodReader is a Reader for the FindConfigCounterCacheSavePeriod structure.

func (*FindConfigCounterCacheSavePeriodReader) ReadResponse ¶

func (o *FindConfigCounterCacheSavePeriodReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCounterCacheSizeInMbDefault ¶

type FindConfigCounterCacheSizeInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCounterCacheSizeInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigCounterCacheSizeInMbDefault ¶

func NewFindConfigCounterCacheSizeInMbDefault(code int) *FindConfigCounterCacheSizeInMbDefault

NewFindConfigCounterCacheSizeInMbDefault creates a FindConfigCounterCacheSizeInMbDefault with default headers values

func (*FindConfigCounterCacheSizeInMbDefault) Code ¶

Code gets the status code for the find config counter cache size in mb default response

func (*FindConfigCounterCacheSizeInMbDefault) Error ¶

func (*FindConfigCounterCacheSizeInMbDefault) GetPayload ¶

type FindConfigCounterCacheSizeInMbOK ¶

type FindConfigCounterCacheSizeInMbOK struct {
	Payload int64
}

FindConfigCounterCacheSizeInMbOK handles this case with default header values.

Config value

func NewFindConfigCounterCacheSizeInMbOK ¶

func NewFindConfigCounterCacheSizeInMbOK() *FindConfigCounterCacheSizeInMbOK

NewFindConfigCounterCacheSizeInMbOK creates a FindConfigCounterCacheSizeInMbOK with default headers values

func (*FindConfigCounterCacheSizeInMbOK) GetPayload ¶

func (o *FindConfigCounterCacheSizeInMbOK) GetPayload() int64

type FindConfigCounterCacheSizeInMbParams ¶

type FindConfigCounterCacheSizeInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCounterCacheSizeInMbParams contains all the parameters to send to the API endpoint for the find config counter cache size in mb operation typically these are written to a http.Request

func NewFindConfigCounterCacheSizeInMbParams ¶

func NewFindConfigCounterCacheSizeInMbParams() *FindConfigCounterCacheSizeInMbParams

NewFindConfigCounterCacheSizeInMbParams creates a new FindConfigCounterCacheSizeInMbParams object with the default values initialized.

func NewFindConfigCounterCacheSizeInMbParamsWithContext ¶

func NewFindConfigCounterCacheSizeInMbParamsWithContext(ctx context.Context) *FindConfigCounterCacheSizeInMbParams

NewFindConfigCounterCacheSizeInMbParamsWithContext creates a new FindConfigCounterCacheSizeInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCounterCacheSizeInMbParamsWithHTTPClient ¶

func NewFindConfigCounterCacheSizeInMbParamsWithHTTPClient(client *http.Client) *FindConfigCounterCacheSizeInMbParams

NewFindConfigCounterCacheSizeInMbParamsWithHTTPClient creates a new FindConfigCounterCacheSizeInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCounterCacheSizeInMbParamsWithTimeout ¶

func NewFindConfigCounterCacheSizeInMbParamsWithTimeout(timeout time.Duration) *FindConfigCounterCacheSizeInMbParams

NewFindConfigCounterCacheSizeInMbParamsWithTimeout creates a new FindConfigCounterCacheSizeInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCounterCacheSizeInMbParams) SetContext ¶

SetContext adds the context to the find config counter cache size in mb params

func (*FindConfigCounterCacheSizeInMbParams) SetHTTPClient ¶

func (o *FindConfigCounterCacheSizeInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config counter cache size in mb params

func (*FindConfigCounterCacheSizeInMbParams) SetTimeout ¶

func (o *FindConfigCounterCacheSizeInMbParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config counter cache size in mb params

func (*FindConfigCounterCacheSizeInMbParams) WithContext ¶

WithContext adds the context to the find config counter cache size in mb params

func (*FindConfigCounterCacheSizeInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config counter cache size in mb params

func (*FindConfigCounterCacheSizeInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config counter cache size in mb params

func (*FindConfigCounterCacheSizeInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCounterCacheSizeInMbReader ¶

type FindConfigCounterCacheSizeInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigCounterCacheSizeInMbReader is a Reader for the FindConfigCounterCacheSizeInMb structure.

func (*FindConfigCounterCacheSizeInMbReader) ReadResponse ¶

func (o *FindConfigCounterCacheSizeInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCounterWriteRequestTimeoutInMsDefault ¶

type FindConfigCounterWriteRequestTimeoutInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCounterWriteRequestTimeoutInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigCounterWriteRequestTimeoutInMsDefault ¶

func NewFindConfigCounterWriteRequestTimeoutInMsDefault(code int) *FindConfigCounterWriteRequestTimeoutInMsDefault

NewFindConfigCounterWriteRequestTimeoutInMsDefault creates a FindConfigCounterWriteRequestTimeoutInMsDefault with default headers values

func (*FindConfigCounterWriteRequestTimeoutInMsDefault) Code ¶

Code gets the status code for the find config counter write request timeout in ms default response

func (*FindConfigCounterWriteRequestTimeoutInMsDefault) Error ¶

func (*FindConfigCounterWriteRequestTimeoutInMsDefault) GetPayload ¶

type FindConfigCounterWriteRequestTimeoutInMsOK ¶

type FindConfigCounterWriteRequestTimeoutInMsOK struct {
	Payload int64
}

FindConfigCounterWriteRequestTimeoutInMsOK handles this case with default header values.

Config value

func NewFindConfigCounterWriteRequestTimeoutInMsOK ¶

func NewFindConfigCounterWriteRequestTimeoutInMsOK() *FindConfigCounterWriteRequestTimeoutInMsOK

NewFindConfigCounterWriteRequestTimeoutInMsOK creates a FindConfigCounterWriteRequestTimeoutInMsOK with default headers values

func (*FindConfigCounterWriteRequestTimeoutInMsOK) GetPayload ¶

type FindConfigCounterWriteRequestTimeoutInMsParams ¶

type FindConfigCounterWriteRequestTimeoutInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCounterWriteRequestTimeoutInMsParams contains all the parameters to send to the API endpoint for the find config counter write request timeout in ms operation typically these are written to a http.Request

func NewFindConfigCounterWriteRequestTimeoutInMsParams ¶

func NewFindConfigCounterWriteRequestTimeoutInMsParams() *FindConfigCounterWriteRequestTimeoutInMsParams

NewFindConfigCounterWriteRequestTimeoutInMsParams creates a new FindConfigCounterWriteRequestTimeoutInMsParams object with the default values initialized.

func NewFindConfigCounterWriteRequestTimeoutInMsParamsWithContext ¶

func NewFindConfigCounterWriteRequestTimeoutInMsParamsWithContext(ctx context.Context) *FindConfigCounterWriteRequestTimeoutInMsParams

NewFindConfigCounterWriteRequestTimeoutInMsParamsWithContext creates a new FindConfigCounterWriteRequestTimeoutInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCounterWriteRequestTimeoutInMsParamsWithHTTPClient ¶

func NewFindConfigCounterWriteRequestTimeoutInMsParamsWithHTTPClient(client *http.Client) *FindConfigCounterWriteRequestTimeoutInMsParams

NewFindConfigCounterWriteRequestTimeoutInMsParamsWithHTTPClient creates a new FindConfigCounterWriteRequestTimeoutInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCounterWriteRequestTimeoutInMsParamsWithTimeout ¶

func NewFindConfigCounterWriteRequestTimeoutInMsParamsWithTimeout(timeout time.Duration) *FindConfigCounterWriteRequestTimeoutInMsParams

NewFindConfigCounterWriteRequestTimeoutInMsParamsWithTimeout creates a new FindConfigCounterWriteRequestTimeoutInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCounterWriteRequestTimeoutInMsParams) SetContext ¶

SetContext adds the context to the find config counter write request timeout in ms params

func (*FindConfigCounterWriteRequestTimeoutInMsParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config counter write request timeout in ms params

func (*FindConfigCounterWriteRequestTimeoutInMsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config counter write request timeout in ms params

func (*FindConfigCounterWriteRequestTimeoutInMsParams) WithContext ¶

WithContext adds the context to the find config counter write request timeout in ms params

func (*FindConfigCounterWriteRequestTimeoutInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config counter write request timeout in ms params

func (*FindConfigCounterWriteRequestTimeoutInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config counter write request timeout in ms params

func (*FindConfigCounterWriteRequestTimeoutInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCounterWriteRequestTimeoutInMsReader ¶

type FindConfigCounterWriteRequestTimeoutInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigCounterWriteRequestTimeoutInMsReader is a Reader for the FindConfigCounterWriteRequestTimeoutInMs structure.

func (*FindConfigCounterWriteRequestTimeoutInMsReader) ReadResponse ¶

func (o *FindConfigCounterWriteRequestTimeoutInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigCrossNodeTimeoutDefault ¶

type FindConfigCrossNodeTimeoutDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigCrossNodeTimeoutDefault handles this case with default header values.

unexpected error

func NewFindConfigCrossNodeTimeoutDefault ¶

func NewFindConfigCrossNodeTimeoutDefault(code int) *FindConfigCrossNodeTimeoutDefault

NewFindConfigCrossNodeTimeoutDefault creates a FindConfigCrossNodeTimeoutDefault with default headers values

func (*FindConfigCrossNodeTimeoutDefault) Code ¶

Code gets the status code for the find config cross node timeout default response

func (*FindConfigCrossNodeTimeoutDefault) Error ¶

func (*FindConfigCrossNodeTimeoutDefault) GetPayload ¶

type FindConfigCrossNodeTimeoutOK ¶

type FindConfigCrossNodeTimeoutOK struct {
	Payload bool
}

FindConfigCrossNodeTimeoutOK handles this case with default header values.

Config value

func NewFindConfigCrossNodeTimeoutOK ¶

func NewFindConfigCrossNodeTimeoutOK() *FindConfigCrossNodeTimeoutOK

NewFindConfigCrossNodeTimeoutOK creates a FindConfigCrossNodeTimeoutOK with default headers values

func (*FindConfigCrossNodeTimeoutOK) GetPayload ¶

func (o *FindConfigCrossNodeTimeoutOK) GetPayload() bool

type FindConfigCrossNodeTimeoutParams ¶

type FindConfigCrossNodeTimeoutParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigCrossNodeTimeoutParams contains all the parameters to send to the API endpoint for the find config cross node timeout operation typically these are written to a http.Request

func NewFindConfigCrossNodeTimeoutParams ¶

func NewFindConfigCrossNodeTimeoutParams() *FindConfigCrossNodeTimeoutParams

NewFindConfigCrossNodeTimeoutParams creates a new FindConfigCrossNodeTimeoutParams object with the default values initialized.

func NewFindConfigCrossNodeTimeoutParamsWithContext ¶

func NewFindConfigCrossNodeTimeoutParamsWithContext(ctx context.Context) *FindConfigCrossNodeTimeoutParams

NewFindConfigCrossNodeTimeoutParamsWithContext creates a new FindConfigCrossNodeTimeoutParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigCrossNodeTimeoutParamsWithHTTPClient ¶

func NewFindConfigCrossNodeTimeoutParamsWithHTTPClient(client *http.Client) *FindConfigCrossNodeTimeoutParams

NewFindConfigCrossNodeTimeoutParamsWithHTTPClient creates a new FindConfigCrossNodeTimeoutParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigCrossNodeTimeoutParamsWithTimeout ¶

func NewFindConfigCrossNodeTimeoutParamsWithTimeout(timeout time.Duration) *FindConfigCrossNodeTimeoutParams

NewFindConfigCrossNodeTimeoutParamsWithTimeout creates a new FindConfigCrossNodeTimeoutParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigCrossNodeTimeoutParams) SetContext ¶

SetContext adds the context to the find config cross node timeout params

func (*FindConfigCrossNodeTimeoutParams) SetHTTPClient ¶

func (o *FindConfigCrossNodeTimeoutParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config cross node timeout params

func (*FindConfigCrossNodeTimeoutParams) SetTimeout ¶

func (o *FindConfigCrossNodeTimeoutParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config cross node timeout params

func (*FindConfigCrossNodeTimeoutParams) WithContext ¶

WithContext adds the context to the find config cross node timeout params

func (*FindConfigCrossNodeTimeoutParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config cross node timeout params

func (*FindConfigCrossNodeTimeoutParams) WithTimeout ¶

WithTimeout adds the timeout to the find config cross node timeout params

func (*FindConfigCrossNodeTimeoutParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigCrossNodeTimeoutReader ¶

type FindConfigCrossNodeTimeoutReader struct {
	// contains filtered or unexported fields
}

FindConfigCrossNodeTimeoutReader is a Reader for the FindConfigCrossNodeTimeout structure.

func (*FindConfigCrossNodeTimeoutReader) ReadResponse ¶

func (o *FindConfigCrossNodeTimeoutReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigDataFileDirectoriesDefault ¶

type FindConfigDataFileDirectoriesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigDataFileDirectoriesDefault handles this case with default header values.

unexpected error

func NewFindConfigDataFileDirectoriesDefault ¶

func NewFindConfigDataFileDirectoriesDefault(code int) *FindConfigDataFileDirectoriesDefault

NewFindConfigDataFileDirectoriesDefault creates a FindConfigDataFileDirectoriesDefault with default headers values

func (*FindConfigDataFileDirectoriesDefault) Code ¶

Code gets the status code for the find config data file directories default response

func (*FindConfigDataFileDirectoriesDefault) Error ¶

func (*FindConfigDataFileDirectoriesDefault) GetPayload ¶

type FindConfigDataFileDirectoriesOK ¶

type FindConfigDataFileDirectoriesOK struct {
	Payload []string
}

FindConfigDataFileDirectoriesOK handles this case with default header values.

Config value

func NewFindConfigDataFileDirectoriesOK ¶

func NewFindConfigDataFileDirectoriesOK() *FindConfigDataFileDirectoriesOK

NewFindConfigDataFileDirectoriesOK creates a FindConfigDataFileDirectoriesOK with default headers values

func (*FindConfigDataFileDirectoriesOK) GetPayload ¶

func (o *FindConfigDataFileDirectoriesOK) GetPayload() []string

type FindConfigDataFileDirectoriesParams ¶

type FindConfigDataFileDirectoriesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigDataFileDirectoriesParams contains all the parameters to send to the API endpoint for the find config data file directories operation typically these are written to a http.Request

func NewFindConfigDataFileDirectoriesParams ¶

func NewFindConfigDataFileDirectoriesParams() *FindConfigDataFileDirectoriesParams

NewFindConfigDataFileDirectoriesParams creates a new FindConfigDataFileDirectoriesParams object with the default values initialized.

func NewFindConfigDataFileDirectoriesParamsWithContext ¶

func NewFindConfigDataFileDirectoriesParamsWithContext(ctx context.Context) *FindConfigDataFileDirectoriesParams

NewFindConfigDataFileDirectoriesParamsWithContext creates a new FindConfigDataFileDirectoriesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigDataFileDirectoriesParamsWithHTTPClient ¶

func NewFindConfigDataFileDirectoriesParamsWithHTTPClient(client *http.Client) *FindConfigDataFileDirectoriesParams

NewFindConfigDataFileDirectoriesParamsWithHTTPClient creates a new FindConfigDataFileDirectoriesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigDataFileDirectoriesParamsWithTimeout ¶

func NewFindConfigDataFileDirectoriesParamsWithTimeout(timeout time.Duration) *FindConfigDataFileDirectoriesParams

NewFindConfigDataFileDirectoriesParamsWithTimeout creates a new FindConfigDataFileDirectoriesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigDataFileDirectoriesParams) SetContext ¶

SetContext adds the context to the find config data file directories params

func (*FindConfigDataFileDirectoriesParams) SetHTTPClient ¶

func (o *FindConfigDataFileDirectoriesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config data file directories params

func (*FindConfigDataFileDirectoriesParams) SetTimeout ¶

func (o *FindConfigDataFileDirectoriesParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config data file directories params

func (*FindConfigDataFileDirectoriesParams) WithContext ¶

WithContext adds the context to the find config data file directories params

func (*FindConfigDataFileDirectoriesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config data file directories params

func (*FindConfigDataFileDirectoriesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config data file directories params

func (*FindConfigDataFileDirectoriesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigDataFileDirectoriesReader ¶

type FindConfigDataFileDirectoriesReader struct {
	// contains filtered or unexported fields
}

FindConfigDataFileDirectoriesReader is a Reader for the FindConfigDataFileDirectories structure.

func (*FindConfigDataFileDirectoriesReader) ReadResponse ¶

func (o *FindConfigDataFileDirectoriesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigDefaultLogLevelDefault ¶

type FindConfigDefaultLogLevelDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigDefaultLogLevelDefault handles this case with default header values.

unexpected error

func NewFindConfigDefaultLogLevelDefault ¶

func NewFindConfigDefaultLogLevelDefault(code int) *FindConfigDefaultLogLevelDefault

NewFindConfigDefaultLogLevelDefault creates a FindConfigDefaultLogLevelDefault with default headers values

func (*FindConfigDefaultLogLevelDefault) Code ¶

Code gets the status code for the find config default log level default response

func (*FindConfigDefaultLogLevelDefault) Error ¶

func (*FindConfigDefaultLogLevelDefault) GetPayload ¶

type FindConfigDefaultLogLevelOK ¶

type FindConfigDefaultLogLevelOK struct {
	Payload string
}

FindConfigDefaultLogLevelOK handles this case with default header values.

Config value

func NewFindConfigDefaultLogLevelOK ¶

func NewFindConfigDefaultLogLevelOK() *FindConfigDefaultLogLevelOK

NewFindConfigDefaultLogLevelOK creates a FindConfigDefaultLogLevelOK with default headers values

func (*FindConfigDefaultLogLevelOK) GetPayload ¶

func (o *FindConfigDefaultLogLevelOK) GetPayload() string

type FindConfigDefaultLogLevelParams ¶

type FindConfigDefaultLogLevelParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigDefaultLogLevelParams contains all the parameters to send to the API endpoint for the find config default log level operation typically these are written to a http.Request

func NewFindConfigDefaultLogLevelParams ¶

func NewFindConfigDefaultLogLevelParams() *FindConfigDefaultLogLevelParams

NewFindConfigDefaultLogLevelParams creates a new FindConfigDefaultLogLevelParams object with the default values initialized.

func NewFindConfigDefaultLogLevelParamsWithContext ¶

func NewFindConfigDefaultLogLevelParamsWithContext(ctx context.Context) *FindConfigDefaultLogLevelParams

NewFindConfigDefaultLogLevelParamsWithContext creates a new FindConfigDefaultLogLevelParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigDefaultLogLevelParamsWithHTTPClient ¶

func NewFindConfigDefaultLogLevelParamsWithHTTPClient(client *http.Client) *FindConfigDefaultLogLevelParams

NewFindConfigDefaultLogLevelParamsWithHTTPClient creates a new FindConfigDefaultLogLevelParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigDefaultLogLevelParamsWithTimeout ¶

func NewFindConfigDefaultLogLevelParamsWithTimeout(timeout time.Duration) *FindConfigDefaultLogLevelParams

NewFindConfigDefaultLogLevelParamsWithTimeout creates a new FindConfigDefaultLogLevelParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigDefaultLogLevelParams) SetContext ¶

func (o *FindConfigDefaultLogLevelParams) SetContext(ctx context.Context)

SetContext adds the context to the find config default log level params

func (*FindConfigDefaultLogLevelParams) SetHTTPClient ¶

func (o *FindConfigDefaultLogLevelParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config default log level params

func (*FindConfigDefaultLogLevelParams) SetTimeout ¶

func (o *FindConfigDefaultLogLevelParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config default log level params

func (*FindConfigDefaultLogLevelParams) WithContext ¶

WithContext adds the context to the find config default log level params

func (*FindConfigDefaultLogLevelParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config default log level params

func (*FindConfigDefaultLogLevelParams) WithTimeout ¶

WithTimeout adds the timeout to the find config default log level params

func (*FindConfigDefaultLogLevelParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigDefaultLogLevelReader ¶

type FindConfigDefaultLogLevelReader struct {
	// contains filtered or unexported fields
}

FindConfigDefaultLogLevelReader is a Reader for the FindConfigDefaultLogLevel structure.

func (*FindConfigDefaultLogLevelReader) ReadResponse ¶

func (o *FindConfigDefaultLogLevelReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigDefragmentMemoryOnIdleDefault ¶

type FindConfigDefragmentMemoryOnIdleDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigDefragmentMemoryOnIdleDefault handles this case with default header values.

unexpected error

func NewFindConfigDefragmentMemoryOnIdleDefault ¶

func NewFindConfigDefragmentMemoryOnIdleDefault(code int) *FindConfigDefragmentMemoryOnIdleDefault

NewFindConfigDefragmentMemoryOnIdleDefault creates a FindConfigDefragmentMemoryOnIdleDefault with default headers values

func (*FindConfigDefragmentMemoryOnIdleDefault) Code ¶

Code gets the status code for the find config defragment memory on idle default response

func (*FindConfigDefragmentMemoryOnIdleDefault) Error ¶

func (*FindConfigDefragmentMemoryOnIdleDefault) GetPayload ¶

type FindConfigDefragmentMemoryOnIdleOK ¶

type FindConfigDefragmentMemoryOnIdleOK struct {
	Payload bool
}

FindConfigDefragmentMemoryOnIdleOK handles this case with default header values.

Config value

func NewFindConfigDefragmentMemoryOnIdleOK ¶

func NewFindConfigDefragmentMemoryOnIdleOK() *FindConfigDefragmentMemoryOnIdleOK

NewFindConfigDefragmentMemoryOnIdleOK creates a FindConfigDefragmentMemoryOnIdleOK with default headers values

func (*FindConfigDefragmentMemoryOnIdleOK) GetPayload ¶

func (o *FindConfigDefragmentMemoryOnIdleOK) GetPayload() bool

type FindConfigDefragmentMemoryOnIdleParams ¶

type FindConfigDefragmentMemoryOnIdleParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigDefragmentMemoryOnIdleParams contains all the parameters to send to the API endpoint for the find config defragment memory on idle operation typically these are written to a http.Request

func NewFindConfigDefragmentMemoryOnIdleParams ¶

func NewFindConfigDefragmentMemoryOnIdleParams() *FindConfigDefragmentMemoryOnIdleParams

NewFindConfigDefragmentMemoryOnIdleParams creates a new FindConfigDefragmentMemoryOnIdleParams object with the default values initialized.

func NewFindConfigDefragmentMemoryOnIdleParamsWithContext ¶

func NewFindConfigDefragmentMemoryOnIdleParamsWithContext(ctx context.Context) *FindConfigDefragmentMemoryOnIdleParams

NewFindConfigDefragmentMemoryOnIdleParamsWithContext creates a new FindConfigDefragmentMemoryOnIdleParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigDefragmentMemoryOnIdleParamsWithHTTPClient ¶

func NewFindConfigDefragmentMemoryOnIdleParamsWithHTTPClient(client *http.Client) *FindConfigDefragmentMemoryOnIdleParams

NewFindConfigDefragmentMemoryOnIdleParamsWithHTTPClient creates a new FindConfigDefragmentMemoryOnIdleParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigDefragmentMemoryOnIdleParamsWithTimeout ¶

func NewFindConfigDefragmentMemoryOnIdleParamsWithTimeout(timeout time.Duration) *FindConfigDefragmentMemoryOnIdleParams

NewFindConfigDefragmentMemoryOnIdleParamsWithTimeout creates a new FindConfigDefragmentMemoryOnIdleParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigDefragmentMemoryOnIdleParams) SetContext ¶

SetContext adds the context to the find config defragment memory on idle params

func (*FindConfigDefragmentMemoryOnIdleParams) SetHTTPClient ¶

func (o *FindConfigDefragmentMemoryOnIdleParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config defragment memory on idle params

func (*FindConfigDefragmentMemoryOnIdleParams) SetTimeout ¶

func (o *FindConfigDefragmentMemoryOnIdleParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config defragment memory on idle params

func (*FindConfigDefragmentMemoryOnIdleParams) WithContext ¶

WithContext adds the context to the find config defragment memory on idle params

func (*FindConfigDefragmentMemoryOnIdleParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config defragment memory on idle params

func (*FindConfigDefragmentMemoryOnIdleParams) WithTimeout ¶

WithTimeout adds the timeout to the find config defragment memory on idle params

func (*FindConfigDefragmentMemoryOnIdleParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigDefragmentMemoryOnIdleReader ¶

type FindConfigDefragmentMemoryOnIdleReader struct {
	// contains filtered or unexported fields
}

FindConfigDefragmentMemoryOnIdleReader is a Reader for the FindConfigDefragmentMemoryOnIdle structure.

func (*FindConfigDefragmentMemoryOnIdleReader) ReadResponse ¶

func (o *FindConfigDefragmentMemoryOnIdleReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigDeveloperModeDefault ¶

type FindConfigDeveloperModeDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigDeveloperModeDefault handles this case with default header values.

unexpected error

func NewFindConfigDeveloperModeDefault ¶

func NewFindConfigDeveloperModeDefault(code int) *FindConfigDeveloperModeDefault

NewFindConfigDeveloperModeDefault creates a FindConfigDeveloperModeDefault with default headers values

func (*FindConfigDeveloperModeDefault) Code ¶

Code gets the status code for the find config developer mode default response

func (*FindConfigDeveloperModeDefault) Error ¶

func (*FindConfigDeveloperModeDefault) GetPayload ¶

type FindConfigDeveloperModeOK ¶

type FindConfigDeveloperModeOK struct {
	Payload bool
}

FindConfigDeveloperModeOK handles this case with default header values.

Config value

func NewFindConfigDeveloperModeOK ¶

func NewFindConfigDeveloperModeOK() *FindConfigDeveloperModeOK

NewFindConfigDeveloperModeOK creates a FindConfigDeveloperModeOK with default headers values

func (*FindConfigDeveloperModeOK) GetPayload ¶

func (o *FindConfigDeveloperModeOK) GetPayload() bool

type FindConfigDeveloperModeParams ¶

type FindConfigDeveloperModeParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigDeveloperModeParams contains all the parameters to send to the API endpoint for the find config developer mode operation typically these are written to a http.Request

func NewFindConfigDeveloperModeParams ¶

func NewFindConfigDeveloperModeParams() *FindConfigDeveloperModeParams

NewFindConfigDeveloperModeParams creates a new FindConfigDeveloperModeParams object with the default values initialized.

func NewFindConfigDeveloperModeParamsWithContext ¶

func NewFindConfigDeveloperModeParamsWithContext(ctx context.Context) *FindConfigDeveloperModeParams

NewFindConfigDeveloperModeParamsWithContext creates a new FindConfigDeveloperModeParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigDeveloperModeParamsWithHTTPClient ¶

func NewFindConfigDeveloperModeParamsWithHTTPClient(client *http.Client) *FindConfigDeveloperModeParams

NewFindConfigDeveloperModeParamsWithHTTPClient creates a new FindConfigDeveloperModeParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigDeveloperModeParamsWithTimeout ¶

func NewFindConfigDeveloperModeParamsWithTimeout(timeout time.Duration) *FindConfigDeveloperModeParams

NewFindConfigDeveloperModeParamsWithTimeout creates a new FindConfigDeveloperModeParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigDeveloperModeParams) SetContext ¶

func (o *FindConfigDeveloperModeParams) SetContext(ctx context.Context)

SetContext adds the context to the find config developer mode params

func (*FindConfigDeveloperModeParams) SetHTTPClient ¶

func (o *FindConfigDeveloperModeParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config developer mode params

func (*FindConfigDeveloperModeParams) SetTimeout ¶

func (o *FindConfigDeveloperModeParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config developer mode params

func (*FindConfigDeveloperModeParams) WithContext ¶

WithContext adds the context to the find config developer mode params

func (*FindConfigDeveloperModeParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config developer mode params

func (*FindConfigDeveloperModeParams) WithTimeout ¶

WithTimeout adds the timeout to the find config developer mode params

func (*FindConfigDeveloperModeParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigDeveloperModeReader ¶

type FindConfigDeveloperModeReader struct {
	// contains filtered or unexported fields
}

FindConfigDeveloperModeReader is a Reader for the FindConfigDeveloperMode structure.

func (*FindConfigDeveloperModeReader) ReadResponse ¶

func (o *FindConfigDeveloperModeReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigDiskFailurePolicyDefault ¶

type FindConfigDiskFailurePolicyDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigDiskFailurePolicyDefault handles this case with default header values.

unexpected error

func NewFindConfigDiskFailurePolicyDefault ¶

func NewFindConfigDiskFailurePolicyDefault(code int) *FindConfigDiskFailurePolicyDefault

NewFindConfigDiskFailurePolicyDefault creates a FindConfigDiskFailurePolicyDefault with default headers values

func (*FindConfigDiskFailurePolicyDefault) Code ¶

Code gets the status code for the find config disk failure policy default response

func (*FindConfigDiskFailurePolicyDefault) Error ¶

func (*FindConfigDiskFailurePolicyDefault) GetPayload ¶

type FindConfigDiskFailurePolicyOK ¶

type FindConfigDiskFailurePolicyOK struct {
	Payload string
}

FindConfigDiskFailurePolicyOK handles this case with default header values.

Config value

func NewFindConfigDiskFailurePolicyOK ¶

func NewFindConfigDiskFailurePolicyOK() *FindConfigDiskFailurePolicyOK

NewFindConfigDiskFailurePolicyOK creates a FindConfigDiskFailurePolicyOK with default headers values

func (*FindConfigDiskFailurePolicyOK) GetPayload ¶

func (o *FindConfigDiskFailurePolicyOK) GetPayload() string

type FindConfigDiskFailurePolicyParams ¶

type FindConfigDiskFailurePolicyParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigDiskFailurePolicyParams contains all the parameters to send to the API endpoint for the find config disk failure policy operation typically these are written to a http.Request

func NewFindConfigDiskFailurePolicyParams ¶

func NewFindConfigDiskFailurePolicyParams() *FindConfigDiskFailurePolicyParams

NewFindConfigDiskFailurePolicyParams creates a new FindConfigDiskFailurePolicyParams object with the default values initialized.

func NewFindConfigDiskFailurePolicyParamsWithContext ¶

func NewFindConfigDiskFailurePolicyParamsWithContext(ctx context.Context) *FindConfigDiskFailurePolicyParams

NewFindConfigDiskFailurePolicyParamsWithContext creates a new FindConfigDiskFailurePolicyParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigDiskFailurePolicyParamsWithHTTPClient ¶

func NewFindConfigDiskFailurePolicyParamsWithHTTPClient(client *http.Client) *FindConfigDiskFailurePolicyParams

NewFindConfigDiskFailurePolicyParamsWithHTTPClient creates a new FindConfigDiskFailurePolicyParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigDiskFailurePolicyParamsWithTimeout ¶

func NewFindConfigDiskFailurePolicyParamsWithTimeout(timeout time.Duration) *FindConfigDiskFailurePolicyParams

NewFindConfigDiskFailurePolicyParamsWithTimeout creates a new FindConfigDiskFailurePolicyParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigDiskFailurePolicyParams) SetContext ¶

SetContext adds the context to the find config disk failure policy params

func (*FindConfigDiskFailurePolicyParams) SetHTTPClient ¶

func (o *FindConfigDiskFailurePolicyParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config disk failure policy params

func (*FindConfigDiskFailurePolicyParams) SetTimeout ¶

func (o *FindConfigDiskFailurePolicyParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config disk failure policy params

func (*FindConfigDiskFailurePolicyParams) WithContext ¶

WithContext adds the context to the find config disk failure policy params

func (*FindConfigDiskFailurePolicyParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config disk failure policy params

func (*FindConfigDiskFailurePolicyParams) WithTimeout ¶

WithTimeout adds the timeout to the find config disk failure policy params

func (*FindConfigDiskFailurePolicyParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigDiskFailurePolicyReader ¶

type FindConfigDiskFailurePolicyReader struct {
	// contains filtered or unexported fields
}

FindConfigDiskFailurePolicyReader is a Reader for the FindConfigDiskFailurePolicy structure.

func (*FindConfigDiskFailurePolicyReader) ReadResponse ¶

func (o *FindConfigDiskFailurePolicyReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigDynamicSnitchBadnessThresholdDefault ¶

type FindConfigDynamicSnitchBadnessThresholdDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchBadnessThresholdDefault handles this case with default header values.

unexpected error

func NewFindConfigDynamicSnitchBadnessThresholdDefault ¶

func NewFindConfigDynamicSnitchBadnessThresholdDefault(code int) *FindConfigDynamicSnitchBadnessThresholdDefault

NewFindConfigDynamicSnitchBadnessThresholdDefault creates a FindConfigDynamicSnitchBadnessThresholdDefault with default headers values

func (*FindConfigDynamicSnitchBadnessThresholdDefault) Code ¶

Code gets the status code for the find config dynamic snitch badness threshold default response

func (*FindConfigDynamicSnitchBadnessThresholdDefault) Error ¶

func (*FindConfigDynamicSnitchBadnessThresholdDefault) GetPayload ¶

type FindConfigDynamicSnitchBadnessThresholdOK ¶

type FindConfigDynamicSnitchBadnessThresholdOK struct {
	Payload float64
}

FindConfigDynamicSnitchBadnessThresholdOK handles this case with default header values.

Config value

func NewFindConfigDynamicSnitchBadnessThresholdOK ¶

func NewFindConfigDynamicSnitchBadnessThresholdOK() *FindConfigDynamicSnitchBadnessThresholdOK

NewFindConfigDynamicSnitchBadnessThresholdOK creates a FindConfigDynamicSnitchBadnessThresholdOK with default headers values

func (*FindConfigDynamicSnitchBadnessThresholdOK) GetPayload ¶

type FindConfigDynamicSnitchBadnessThresholdParams ¶

type FindConfigDynamicSnitchBadnessThresholdParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchBadnessThresholdParams contains all the parameters to send to the API endpoint for the find config dynamic snitch badness threshold operation typically these are written to a http.Request

func NewFindConfigDynamicSnitchBadnessThresholdParams ¶

func NewFindConfigDynamicSnitchBadnessThresholdParams() *FindConfigDynamicSnitchBadnessThresholdParams

NewFindConfigDynamicSnitchBadnessThresholdParams creates a new FindConfigDynamicSnitchBadnessThresholdParams object with the default values initialized.

func NewFindConfigDynamicSnitchBadnessThresholdParamsWithContext ¶

func NewFindConfigDynamicSnitchBadnessThresholdParamsWithContext(ctx context.Context) *FindConfigDynamicSnitchBadnessThresholdParams

NewFindConfigDynamicSnitchBadnessThresholdParamsWithContext creates a new FindConfigDynamicSnitchBadnessThresholdParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigDynamicSnitchBadnessThresholdParamsWithHTTPClient ¶

func NewFindConfigDynamicSnitchBadnessThresholdParamsWithHTTPClient(client *http.Client) *FindConfigDynamicSnitchBadnessThresholdParams

NewFindConfigDynamicSnitchBadnessThresholdParamsWithHTTPClient creates a new FindConfigDynamicSnitchBadnessThresholdParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigDynamicSnitchBadnessThresholdParamsWithTimeout ¶

func NewFindConfigDynamicSnitchBadnessThresholdParamsWithTimeout(timeout time.Duration) *FindConfigDynamicSnitchBadnessThresholdParams

NewFindConfigDynamicSnitchBadnessThresholdParamsWithTimeout creates a new FindConfigDynamicSnitchBadnessThresholdParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigDynamicSnitchBadnessThresholdParams) SetContext ¶

SetContext adds the context to the find config dynamic snitch badness threshold params

func (*FindConfigDynamicSnitchBadnessThresholdParams) SetHTTPClient ¶

func (o *FindConfigDynamicSnitchBadnessThresholdParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config dynamic snitch badness threshold params

func (*FindConfigDynamicSnitchBadnessThresholdParams) SetTimeout ¶

SetTimeout adds the timeout to the find config dynamic snitch badness threshold params

func (*FindConfigDynamicSnitchBadnessThresholdParams) WithContext ¶

WithContext adds the context to the find config dynamic snitch badness threshold params

func (*FindConfigDynamicSnitchBadnessThresholdParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config dynamic snitch badness threshold params

func (*FindConfigDynamicSnitchBadnessThresholdParams) WithTimeout ¶

WithTimeout adds the timeout to the find config dynamic snitch badness threshold params

func (*FindConfigDynamicSnitchBadnessThresholdParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigDynamicSnitchBadnessThresholdReader ¶

type FindConfigDynamicSnitchBadnessThresholdReader struct {
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchBadnessThresholdReader is a Reader for the FindConfigDynamicSnitchBadnessThreshold structure.

func (*FindConfigDynamicSnitchBadnessThresholdReader) ReadResponse ¶

func (o *FindConfigDynamicSnitchBadnessThresholdReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigDynamicSnitchResetIntervalInMsDefault ¶

type FindConfigDynamicSnitchResetIntervalInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchResetIntervalInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigDynamicSnitchResetIntervalInMsDefault ¶

func NewFindConfigDynamicSnitchResetIntervalInMsDefault(code int) *FindConfigDynamicSnitchResetIntervalInMsDefault

NewFindConfigDynamicSnitchResetIntervalInMsDefault creates a FindConfigDynamicSnitchResetIntervalInMsDefault with default headers values

func (*FindConfigDynamicSnitchResetIntervalInMsDefault) Code ¶

Code gets the status code for the find config dynamic snitch reset interval in ms default response

func (*FindConfigDynamicSnitchResetIntervalInMsDefault) Error ¶

func (*FindConfigDynamicSnitchResetIntervalInMsDefault) GetPayload ¶

type FindConfigDynamicSnitchResetIntervalInMsOK ¶

type FindConfigDynamicSnitchResetIntervalInMsOK struct {
	Payload int64
}

FindConfigDynamicSnitchResetIntervalInMsOK handles this case with default header values.

Config value

func NewFindConfigDynamicSnitchResetIntervalInMsOK ¶

func NewFindConfigDynamicSnitchResetIntervalInMsOK() *FindConfigDynamicSnitchResetIntervalInMsOK

NewFindConfigDynamicSnitchResetIntervalInMsOK creates a FindConfigDynamicSnitchResetIntervalInMsOK with default headers values

func (*FindConfigDynamicSnitchResetIntervalInMsOK) GetPayload ¶

type FindConfigDynamicSnitchResetIntervalInMsParams ¶

type FindConfigDynamicSnitchResetIntervalInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchResetIntervalInMsParams contains all the parameters to send to the API endpoint for the find config dynamic snitch reset interval in ms operation typically these are written to a http.Request

func NewFindConfigDynamicSnitchResetIntervalInMsParams ¶

func NewFindConfigDynamicSnitchResetIntervalInMsParams() *FindConfigDynamicSnitchResetIntervalInMsParams

NewFindConfigDynamicSnitchResetIntervalInMsParams creates a new FindConfigDynamicSnitchResetIntervalInMsParams object with the default values initialized.

func NewFindConfigDynamicSnitchResetIntervalInMsParamsWithContext ¶

func NewFindConfigDynamicSnitchResetIntervalInMsParamsWithContext(ctx context.Context) *FindConfigDynamicSnitchResetIntervalInMsParams

NewFindConfigDynamicSnitchResetIntervalInMsParamsWithContext creates a new FindConfigDynamicSnitchResetIntervalInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigDynamicSnitchResetIntervalInMsParamsWithHTTPClient ¶

func NewFindConfigDynamicSnitchResetIntervalInMsParamsWithHTTPClient(client *http.Client) *FindConfigDynamicSnitchResetIntervalInMsParams

NewFindConfigDynamicSnitchResetIntervalInMsParamsWithHTTPClient creates a new FindConfigDynamicSnitchResetIntervalInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigDynamicSnitchResetIntervalInMsParamsWithTimeout ¶

func NewFindConfigDynamicSnitchResetIntervalInMsParamsWithTimeout(timeout time.Duration) *FindConfigDynamicSnitchResetIntervalInMsParams

NewFindConfigDynamicSnitchResetIntervalInMsParamsWithTimeout creates a new FindConfigDynamicSnitchResetIntervalInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigDynamicSnitchResetIntervalInMsParams) SetContext ¶

SetContext adds the context to the find config dynamic snitch reset interval in ms params

func (*FindConfigDynamicSnitchResetIntervalInMsParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config dynamic snitch reset interval in ms params

func (*FindConfigDynamicSnitchResetIntervalInMsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config dynamic snitch reset interval in ms params

func (*FindConfigDynamicSnitchResetIntervalInMsParams) WithContext ¶

WithContext adds the context to the find config dynamic snitch reset interval in ms params

func (*FindConfigDynamicSnitchResetIntervalInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config dynamic snitch reset interval in ms params

func (*FindConfigDynamicSnitchResetIntervalInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config dynamic snitch reset interval in ms params

func (*FindConfigDynamicSnitchResetIntervalInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigDynamicSnitchResetIntervalInMsReader ¶

type FindConfigDynamicSnitchResetIntervalInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchResetIntervalInMsReader is a Reader for the FindConfigDynamicSnitchResetIntervalInMs structure.

func (*FindConfigDynamicSnitchResetIntervalInMsReader) ReadResponse ¶

func (o *FindConfigDynamicSnitchResetIntervalInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigDynamicSnitchUpdateIntervalInMsDefault ¶

type FindConfigDynamicSnitchUpdateIntervalInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchUpdateIntervalInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigDynamicSnitchUpdateIntervalInMsDefault ¶

func NewFindConfigDynamicSnitchUpdateIntervalInMsDefault(code int) *FindConfigDynamicSnitchUpdateIntervalInMsDefault

NewFindConfigDynamicSnitchUpdateIntervalInMsDefault creates a FindConfigDynamicSnitchUpdateIntervalInMsDefault with default headers values

func (*FindConfigDynamicSnitchUpdateIntervalInMsDefault) Code ¶

Code gets the status code for the find config dynamic snitch update interval in ms default response

func (*FindConfigDynamicSnitchUpdateIntervalInMsDefault) Error ¶

func (*FindConfigDynamicSnitchUpdateIntervalInMsDefault) GetPayload ¶

type FindConfigDynamicSnitchUpdateIntervalInMsOK ¶

type FindConfigDynamicSnitchUpdateIntervalInMsOK struct {
	Payload int64
}

FindConfigDynamicSnitchUpdateIntervalInMsOK handles this case with default header values.

Config value

func NewFindConfigDynamicSnitchUpdateIntervalInMsOK ¶

func NewFindConfigDynamicSnitchUpdateIntervalInMsOK() *FindConfigDynamicSnitchUpdateIntervalInMsOK

NewFindConfigDynamicSnitchUpdateIntervalInMsOK creates a FindConfigDynamicSnitchUpdateIntervalInMsOK with default headers values

func (*FindConfigDynamicSnitchUpdateIntervalInMsOK) GetPayload ¶

type FindConfigDynamicSnitchUpdateIntervalInMsParams ¶

type FindConfigDynamicSnitchUpdateIntervalInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchUpdateIntervalInMsParams contains all the parameters to send to the API endpoint for the find config dynamic snitch update interval in ms operation typically these are written to a http.Request

func NewFindConfigDynamicSnitchUpdateIntervalInMsParams ¶

func NewFindConfigDynamicSnitchUpdateIntervalInMsParams() *FindConfigDynamicSnitchUpdateIntervalInMsParams

NewFindConfigDynamicSnitchUpdateIntervalInMsParams creates a new FindConfigDynamicSnitchUpdateIntervalInMsParams object with the default values initialized.

func NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithContext ¶

func NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithContext(ctx context.Context) *FindConfigDynamicSnitchUpdateIntervalInMsParams

NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithContext creates a new FindConfigDynamicSnitchUpdateIntervalInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithHTTPClient ¶

func NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithHTTPClient(client *http.Client) *FindConfigDynamicSnitchUpdateIntervalInMsParams

NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithHTTPClient creates a new FindConfigDynamicSnitchUpdateIntervalInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithTimeout ¶

func NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithTimeout(timeout time.Duration) *FindConfigDynamicSnitchUpdateIntervalInMsParams

NewFindConfigDynamicSnitchUpdateIntervalInMsParamsWithTimeout creates a new FindConfigDynamicSnitchUpdateIntervalInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigDynamicSnitchUpdateIntervalInMsParams) SetContext ¶

SetContext adds the context to the find config dynamic snitch update interval in ms params

func (*FindConfigDynamicSnitchUpdateIntervalInMsParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config dynamic snitch update interval in ms params

func (*FindConfigDynamicSnitchUpdateIntervalInMsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config dynamic snitch update interval in ms params

func (*FindConfigDynamicSnitchUpdateIntervalInMsParams) WithContext ¶

WithContext adds the context to the find config dynamic snitch update interval in ms params

func (*FindConfigDynamicSnitchUpdateIntervalInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config dynamic snitch update interval in ms params

func (*FindConfigDynamicSnitchUpdateIntervalInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config dynamic snitch update interval in ms params

func (*FindConfigDynamicSnitchUpdateIntervalInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigDynamicSnitchUpdateIntervalInMsReader ¶

type FindConfigDynamicSnitchUpdateIntervalInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigDynamicSnitchUpdateIntervalInMsReader is a Reader for the FindConfigDynamicSnitchUpdateIntervalInMs structure.

func (*FindConfigDynamicSnitchUpdateIntervalInMsReader) ReadResponse ¶

func (o *FindConfigDynamicSnitchUpdateIntervalInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEnableCacheDefault ¶

type FindConfigEnableCacheDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableCacheDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableCacheDefault ¶

func NewFindConfigEnableCacheDefault(code int) *FindConfigEnableCacheDefault

NewFindConfigEnableCacheDefault creates a FindConfigEnableCacheDefault with default headers values

func (*FindConfigEnableCacheDefault) Code ¶

Code gets the status code for the find config enable cache default response

func (*FindConfigEnableCacheDefault) Error ¶

func (*FindConfigEnableCacheDefault) GetPayload ¶

type FindConfigEnableCacheOK ¶

type FindConfigEnableCacheOK struct {
	Payload bool
}

FindConfigEnableCacheOK handles this case with default header values.

Config value

func NewFindConfigEnableCacheOK ¶

func NewFindConfigEnableCacheOK() *FindConfigEnableCacheOK

NewFindConfigEnableCacheOK creates a FindConfigEnableCacheOK with default headers values

func (*FindConfigEnableCacheOK) GetPayload ¶

func (o *FindConfigEnableCacheOK) GetPayload() bool

type FindConfigEnableCacheParams ¶

type FindConfigEnableCacheParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableCacheParams contains all the parameters to send to the API endpoint for the find config enable cache operation typically these are written to a http.Request

func NewFindConfigEnableCacheParams ¶

func NewFindConfigEnableCacheParams() *FindConfigEnableCacheParams

NewFindConfigEnableCacheParams creates a new FindConfigEnableCacheParams object with the default values initialized.

func NewFindConfigEnableCacheParamsWithContext ¶

func NewFindConfigEnableCacheParamsWithContext(ctx context.Context) *FindConfigEnableCacheParams

NewFindConfigEnableCacheParamsWithContext creates a new FindConfigEnableCacheParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableCacheParamsWithHTTPClient ¶

func NewFindConfigEnableCacheParamsWithHTTPClient(client *http.Client) *FindConfigEnableCacheParams

NewFindConfigEnableCacheParamsWithHTTPClient creates a new FindConfigEnableCacheParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableCacheParamsWithTimeout ¶

func NewFindConfigEnableCacheParamsWithTimeout(timeout time.Duration) *FindConfigEnableCacheParams

NewFindConfigEnableCacheParamsWithTimeout creates a new FindConfigEnableCacheParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableCacheParams) SetContext ¶

func (o *FindConfigEnableCacheParams) SetContext(ctx context.Context)

SetContext adds the context to the find config enable cache params

func (*FindConfigEnableCacheParams) SetHTTPClient ¶

func (o *FindConfigEnableCacheParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config enable cache params

func (*FindConfigEnableCacheParams) SetTimeout ¶

func (o *FindConfigEnableCacheParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config enable cache params

func (*FindConfigEnableCacheParams) WithContext ¶

WithContext adds the context to the find config enable cache params

func (*FindConfigEnableCacheParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable cache params

func (*FindConfigEnableCacheParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable cache params

func (*FindConfigEnableCacheParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableCacheReader ¶

type FindConfigEnableCacheReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableCacheReader is a Reader for the FindConfigEnableCache structure.

func (*FindConfigEnableCacheReader) ReadResponse ¶

func (o *FindConfigEnableCacheReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEnableCommitlogDefault ¶

type FindConfigEnableCommitlogDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableCommitlogDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableCommitlogDefault ¶

func NewFindConfigEnableCommitlogDefault(code int) *FindConfigEnableCommitlogDefault

NewFindConfigEnableCommitlogDefault creates a FindConfigEnableCommitlogDefault with default headers values

func (*FindConfigEnableCommitlogDefault) Code ¶

Code gets the status code for the find config enable commitlog default response

func (*FindConfigEnableCommitlogDefault) Error ¶

func (*FindConfigEnableCommitlogDefault) GetPayload ¶

type FindConfigEnableCommitlogOK ¶

type FindConfigEnableCommitlogOK struct {
	Payload bool
}

FindConfigEnableCommitlogOK handles this case with default header values.

Config value

func NewFindConfigEnableCommitlogOK ¶

func NewFindConfigEnableCommitlogOK() *FindConfigEnableCommitlogOK

NewFindConfigEnableCommitlogOK creates a FindConfigEnableCommitlogOK with default headers values

func (*FindConfigEnableCommitlogOK) GetPayload ¶

func (o *FindConfigEnableCommitlogOK) GetPayload() bool

type FindConfigEnableCommitlogParams ¶

type FindConfigEnableCommitlogParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableCommitlogParams contains all the parameters to send to the API endpoint for the find config enable commitlog operation typically these are written to a http.Request

func NewFindConfigEnableCommitlogParams ¶

func NewFindConfigEnableCommitlogParams() *FindConfigEnableCommitlogParams

NewFindConfigEnableCommitlogParams creates a new FindConfigEnableCommitlogParams object with the default values initialized.

func NewFindConfigEnableCommitlogParamsWithContext ¶

func NewFindConfigEnableCommitlogParamsWithContext(ctx context.Context) *FindConfigEnableCommitlogParams

NewFindConfigEnableCommitlogParamsWithContext creates a new FindConfigEnableCommitlogParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableCommitlogParamsWithHTTPClient ¶

func NewFindConfigEnableCommitlogParamsWithHTTPClient(client *http.Client) *FindConfigEnableCommitlogParams

NewFindConfigEnableCommitlogParamsWithHTTPClient creates a new FindConfigEnableCommitlogParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableCommitlogParamsWithTimeout ¶

func NewFindConfigEnableCommitlogParamsWithTimeout(timeout time.Duration) *FindConfigEnableCommitlogParams

NewFindConfigEnableCommitlogParamsWithTimeout creates a new FindConfigEnableCommitlogParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableCommitlogParams) SetContext ¶

func (o *FindConfigEnableCommitlogParams) SetContext(ctx context.Context)

SetContext adds the context to the find config enable commitlog params

func (*FindConfigEnableCommitlogParams) SetHTTPClient ¶

func (o *FindConfigEnableCommitlogParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config enable commitlog params

func (*FindConfigEnableCommitlogParams) SetTimeout ¶

func (o *FindConfigEnableCommitlogParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config enable commitlog params

func (*FindConfigEnableCommitlogParams) WithContext ¶

WithContext adds the context to the find config enable commitlog params

func (*FindConfigEnableCommitlogParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable commitlog params

func (*FindConfigEnableCommitlogParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable commitlog params

func (*FindConfigEnableCommitlogParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableCommitlogReader ¶

type FindConfigEnableCommitlogReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableCommitlogReader is a Reader for the FindConfigEnableCommitlog structure.

func (*FindConfigEnableCommitlogReader) ReadResponse ¶

func (o *FindConfigEnableCommitlogReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEnableDangerousDirectImportOfCassandraCountersDefault ¶

type FindConfigEnableDangerousDirectImportOfCassandraCountersDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableDangerousDirectImportOfCassandraCountersDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersDefault ¶

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersDefault(code int) *FindConfigEnableDangerousDirectImportOfCassandraCountersDefault

NewFindConfigEnableDangerousDirectImportOfCassandraCountersDefault creates a FindConfigEnableDangerousDirectImportOfCassandraCountersDefault with default headers values

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersDefault) Code ¶

Code gets the status code for the find config enable dangerous direct import of cassandra counters default response

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersDefault) Error ¶

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersDefault) GetPayload ¶

type FindConfigEnableDangerousDirectImportOfCassandraCountersOK ¶

type FindConfigEnableDangerousDirectImportOfCassandraCountersOK struct {
	Payload bool
}

FindConfigEnableDangerousDirectImportOfCassandraCountersOK handles this case with default header values.

Config value

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersOK ¶

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersOK() *FindConfigEnableDangerousDirectImportOfCassandraCountersOK

NewFindConfigEnableDangerousDirectImportOfCassandraCountersOK creates a FindConfigEnableDangerousDirectImportOfCassandraCountersOK with default headers values

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersOK) GetPayload ¶

type FindConfigEnableDangerousDirectImportOfCassandraCountersParams ¶

type FindConfigEnableDangerousDirectImportOfCassandraCountersParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableDangerousDirectImportOfCassandraCountersParams contains all the parameters to send to the API endpoint for the find config enable dangerous direct import of cassandra counters operation typically these are written to a http.Request

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersParams ¶

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersParams() *FindConfigEnableDangerousDirectImportOfCassandraCountersParams

NewFindConfigEnableDangerousDirectImportOfCassandraCountersParams creates a new FindConfigEnableDangerousDirectImportOfCassandraCountersParams object with the default values initialized.

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithContext ¶

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithContext(ctx context.Context) *FindConfigEnableDangerousDirectImportOfCassandraCountersParams

NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithContext creates a new FindConfigEnableDangerousDirectImportOfCassandraCountersParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithHTTPClient ¶

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithHTTPClient(client *http.Client) *FindConfigEnableDangerousDirectImportOfCassandraCountersParams

NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithHTTPClient creates a new FindConfigEnableDangerousDirectImportOfCassandraCountersParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithTimeout ¶

func NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithTimeout(timeout time.Duration) *FindConfigEnableDangerousDirectImportOfCassandraCountersParams

NewFindConfigEnableDangerousDirectImportOfCassandraCountersParamsWithTimeout creates a new FindConfigEnableDangerousDirectImportOfCassandraCountersParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersParams) SetContext ¶

SetContext adds the context to the find config enable dangerous direct import of cassandra counters params

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config enable dangerous direct import of cassandra counters params

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersParams) SetTimeout ¶

SetTimeout adds the timeout to the find config enable dangerous direct import of cassandra counters params

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersParams) WithContext ¶

WithContext adds the context to the find config enable dangerous direct import of cassandra counters params

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable dangerous direct import of cassandra counters params

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable dangerous direct import of cassandra counters params

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableDangerousDirectImportOfCassandraCountersReader ¶

type FindConfigEnableDangerousDirectImportOfCassandraCountersReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableDangerousDirectImportOfCassandraCountersReader is a Reader for the FindConfigEnableDangerousDirectImportOfCassandraCounters structure.

func (*FindConfigEnableDangerousDirectImportOfCassandraCountersReader) ReadResponse ¶

ReadResponse reads a server response into the received o.

type FindConfigEnableDeprecatedPartitionersDefault ¶

type FindConfigEnableDeprecatedPartitionersDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableDeprecatedPartitionersDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableDeprecatedPartitionersDefault ¶

func NewFindConfigEnableDeprecatedPartitionersDefault(code int) *FindConfigEnableDeprecatedPartitionersDefault

NewFindConfigEnableDeprecatedPartitionersDefault creates a FindConfigEnableDeprecatedPartitionersDefault with default headers values

func (*FindConfigEnableDeprecatedPartitionersDefault) Code ¶

Code gets the status code for the find config enable deprecated partitioners default response

func (*FindConfigEnableDeprecatedPartitionersDefault) Error ¶

func (*FindConfigEnableDeprecatedPartitionersDefault) GetPayload ¶

type FindConfigEnableDeprecatedPartitionersOK ¶

type FindConfigEnableDeprecatedPartitionersOK struct {
	Payload bool
}

FindConfigEnableDeprecatedPartitionersOK handles this case with default header values.

Config value

func NewFindConfigEnableDeprecatedPartitionersOK ¶

func NewFindConfigEnableDeprecatedPartitionersOK() *FindConfigEnableDeprecatedPartitionersOK

NewFindConfigEnableDeprecatedPartitionersOK creates a FindConfigEnableDeprecatedPartitionersOK with default headers values

func (*FindConfigEnableDeprecatedPartitionersOK) GetPayload ¶

type FindConfigEnableDeprecatedPartitionersParams ¶

type FindConfigEnableDeprecatedPartitionersParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableDeprecatedPartitionersParams contains all the parameters to send to the API endpoint for the find config enable deprecated partitioners operation typically these are written to a http.Request

func NewFindConfigEnableDeprecatedPartitionersParams ¶

func NewFindConfigEnableDeprecatedPartitionersParams() *FindConfigEnableDeprecatedPartitionersParams

NewFindConfigEnableDeprecatedPartitionersParams creates a new FindConfigEnableDeprecatedPartitionersParams object with the default values initialized.

func NewFindConfigEnableDeprecatedPartitionersParamsWithContext ¶

func NewFindConfigEnableDeprecatedPartitionersParamsWithContext(ctx context.Context) *FindConfigEnableDeprecatedPartitionersParams

NewFindConfigEnableDeprecatedPartitionersParamsWithContext creates a new FindConfigEnableDeprecatedPartitionersParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableDeprecatedPartitionersParamsWithHTTPClient ¶

func NewFindConfigEnableDeprecatedPartitionersParamsWithHTTPClient(client *http.Client) *FindConfigEnableDeprecatedPartitionersParams

NewFindConfigEnableDeprecatedPartitionersParamsWithHTTPClient creates a new FindConfigEnableDeprecatedPartitionersParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableDeprecatedPartitionersParamsWithTimeout ¶

func NewFindConfigEnableDeprecatedPartitionersParamsWithTimeout(timeout time.Duration) *FindConfigEnableDeprecatedPartitionersParams

NewFindConfigEnableDeprecatedPartitionersParamsWithTimeout creates a new FindConfigEnableDeprecatedPartitionersParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableDeprecatedPartitionersParams) SetContext ¶

SetContext adds the context to the find config enable deprecated partitioners params

func (*FindConfigEnableDeprecatedPartitionersParams) SetHTTPClient ¶

func (o *FindConfigEnableDeprecatedPartitionersParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config enable deprecated partitioners params

func (*FindConfigEnableDeprecatedPartitionersParams) SetTimeout ¶

SetTimeout adds the timeout to the find config enable deprecated partitioners params

func (*FindConfigEnableDeprecatedPartitionersParams) WithContext ¶

WithContext adds the context to the find config enable deprecated partitioners params

func (*FindConfigEnableDeprecatedPartitionersParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable deprecated partitioners params

func (*FindConfigEnableDeprecatedPartitionersParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable deprecated partitioners params

func (*FindConfigEnableDeprecatedPartitionersParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableDeprecatedPartitionersReader ¶

type FindConfigEnableDeprecatedPartitionersReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableDeprecatedPartitionersReader is a Reader for the FindConfigEnableDeprecatedPartitioners structure.

func (*FindConfigEnableDeprecatedPartitionersReader) ReadResponse ¶

func (o *FindConfigEnableDeprecatedPartitionersReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEnableInMemoryDataStoreDefault ¶

type FindConfigEnableInMemoryDataStoreDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableInMemoryDataStoreDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableInMemoryDataStoreDefault ¶

func NewFindConfigEnableInMemoryDataStoreDefault(code int) *FindConfigEnableInMemoryDataStoreDefault

NewFindConfigEnableInMemoryDataStoreDefault creates a FindConfigEnableInMemoryDataStoreDefault with default headers values

func (*FindConfigEnableInMemoryDataStoreDefault) Code ¶

Code gets the status code for the find config enable in memory data store default response

func (*FindConfigEnableInMemoryDataStoreDefault) Error ¶

func (*FindConfigEnableInMemoryDataStoreDefault) GetPayload ¶

type FindConfigEnableInMemoryDataStoreOK ¶

type FindConfigEnableInMemoryDataStoreOK struct {
	Payload bool
}

FindConfigEnableInMemoryDataStoreOK handles this case with default header values.

Config value

func NewFindConfigEnableInMemoryDataStoreOK ¶

func NewFindConfigEnableInMemoryDataStoreOK() *FindConfigEnableInMemoryDataStoreOK

NewFindConfigEnableInMemoryDataStoreOK creates a FindConfigEnableInMemoryDataStoreOK with default headers values

func (*FindConfigEnableInMemoryDataStoreOK) GetPayload ¶

func (o *FindConfigEnableInMemoryDataStoreOK) GetPayload() bool

type FindConfigEnableInMemoryDataStoreParams ¶

type FindConfigEnableInMemoryDataStoreParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableInMemoryDataStoreParams contains all the parameters to send to the API endpoint for the find config enable in memory data store operation typically these are written to a http.Request

func NewFindConfigEnableInMemoryDataStoreParams ¶

func NewFindConfigEnableInMemoryDataStoreParams() *FindConfigEnableInMemoryDataStoreParams

NewFindConfigEnableInMemoryDataStoreParams creates a new FindConfigEnableInMemoryDataStoreParams object with the default values initialized.

func NewFindConfigEnableInMemoryDataStoreParamsWithContext ¶

func NewFindConfigEnableInMemoryDataStoreParamsWithContext(ctx context.Context) *FindConfigEnableInMemoryDataStoreParams

NewFindConfigEnableInMemoryDataStoreParamsWithContext creates a new FindConfigEnableInMemoryDataStoreParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableInMemoryDataStoreParamsWithHTTPClient ¶

func NewFindConfigEnableInMemoryDataStoreParamsWithHTTPClient(client *http.Client) *FindConfigEnableInMemoryDataStoreParams

NewFindConfigEnableInMemoryDataStoreParamsWithHTTPClient creates a new FindConfigEnableInMemoryDataStoreParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableInMemoryDataStoreParamsWithTimeout ¶

func NewFindConfigEnableInMemoryDataStoreParamsWithTimeout(timeout time.Duration) *FindConfigEnableInMemoryDataStoreParams

NewFindConfigEnableInMemoryDataStoreParamsWithTimeout creates a new FindConfigEnableInMemoryDataStoreParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableInMemoryDataStoreParams) SetContext ¶

SetContext adds the context to the find config enable in memory data store params

func (*FindConfigEnableInMemoryDataStoreParams) SetHTTPClient ¶

func (o *FindConfigEnableInMemoryDataStoreParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config enable in memory data store params

func (*FindConfigEnableInMemoryDataStoreParams) SetTimeout ¶

func (o *FindConfigEnableInMemoryDataStoreParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config enable in memory data store params

func (*FindConfigEnableInMemoryDataStoreParams) WithContext ¶

WithContext adds the context to the find config enable in memory data store params

func (*FindConfigEnableInMemoryDataStoreParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable in memory data store params

func (*FindConfigEnableInMemoryDataStoreParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable in memory data store params

func (*FindConfigEnableInMemoryDataStoreParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableInMemoryDataStoreReader ¶

type FindConfigEnableInMemoryDataStoreReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableInMemoryDataStoreReader is a Reader for the FindConfigEnableInMemoryDataStore structure.

func (*FindConfigEnableInMemoryDataStoreReader) ReadResponse ¶

func (o *FindConfigEnableInMemoryDataStoreReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEnableKeyspaceColumnFamilyMetricsDefault ¶

type FindConfigEnableKeyspaceColumnFamilyMetricsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableKeyspaceColumnFamilyMetricsDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableKeyspaceColumnFamilyMetricsDefault ¶

func NewFindConfigEnableKeyspaceColumnFamilyMetricsDefault(code int) *FindConfigEnableKeyspaceColumnFamilyMetricsDefault

NewFindConfigEnableKeyspaceColumnFamilyMetricsDefault creates a FindConfigEnableKeyspaceColumnFamilyMetricsDefault with default headers values

func (*FindConfigEnableKeyspaceColumnFamilyMetricsDefault) Code ¶

Code gets the status code for the find config enable keyspace column family metrics default response

func (*FindConfigEnableKeyspaceColumnFamilyMetricsDefault) Error ¶

func (*FindConfigEnableKeyspaceColumnFamilyMetricsDefault) GetPayload ¶

type FindConfigEnableKeyspaceColumnFamilyMetricsOK ¶

type FindConfigEnableKeyspaceColumnFamilyMetricsOK struct {
	Payload bool
}

FindConfigEnableKeyspaceColumnFamilyMetricsOK handles this case with default header values.

Config value

func NewFindConfigEnableKeyspaceColumnFamilyMetricsOK ¶

func NewFindConfigEnableKeyspaceColumnFamilyMetricsOK() *FindConfigEnableKeyspaceColumnFamilyMetricsOK

NewFindConfigEnableKeyspaceColumnFamilyMetricsOK creates a FindConfigEnableKeyspaceColumnFamilyMetricsOK with default headers values

func (*FindConfigEnableKeyspaceColumnFamilyMetricsOK) GetPayload ¶

type FindConfigEnableKeyspaceColumnFamilyMetricsParams ¶

type FindConfigEnableKeyspaceColumnFamilyMetricsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableKeyspaceColumnFamilyMetricsParams contains all the parameters to send to the API endpoint for the find config enable keyspace column family metrics operation typically these are written to a http.Request

func NewFindConfigEnableKeyspaceColumnFamilyMetricsParams ¶

func NewFindConfigEnableKeyspaceColumnFamilyMetricsParams() *FindConfigEnableKeyspaceColumnFamilyMetricsParams

NewFindConfigEnableKeyspaceColumnFamilyMetricsParams creates a new FindConfigEnableKeyspaceColumnFamilyMetricsParams object with the default values initialized.

func NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithContext ¶

func NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithContext(ctx context.Context) *FindConfigEnableKeyspaceColumnFamilyMetricsParams

NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithContext creates a new FindConfigEnableKeyspaceColumnFamilyMetricsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithHTTPClient ¶

func NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithHTTPClient(client *http.Client) *FindConfigEnableKeyspaceColumnFamilyMetricsParams

NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithHTTPClient creates a new FindConfigEnableKeyspaceColumnFamilyMetricsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithTimeout ¶

func NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithTimeout(timeout time.Duration) *FindConfigEnableKeyspaceColumnFamilyMetricsParams

NewFindConfigEnableKeyspaceColumnFamilyMetricsParamsWithTimeout creates a new FindConfigEnableKeyspaceColumnFamilyMetricsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableKeyspaceColumnFamilyMetricsParams) SetContext ¶

SetContext adds the context to the find config enable keyspace column family metrics params

func (*FindConfigEnableKeyspaceColumnFamilyMetricsParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config enable keyspace column family metrics params

func (*FindConfigEnableKeyspaceColumnFamilyMetricsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config enable keyspace column family metrics params

func (*FindConfigEnableKeyspaceColumnFamilyMetricsParams) WithContext ¶

WithContext adds the context to the find config enable keyspace column family metrics params

func (*FindConfigEnableKeyspaceColumnFamilyMetricsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable keyspace column family metrics params

func (*FindConfigEnableKeyspaceColumnFamilyMetricsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable keyspace column family metrics params

func (*FindConfigEnableKeyspaceColumnFamilyMetricsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableKeyspaceColumnFamilyMetricsReader ¶

type FindConfigEnableKeyspaceColumnFamilyMetricsReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableKeyspaceColumnFamilyMetricsReader is a Reader for the FindConfigEnableKeyspaceColumnFamilyMetrics structure.

func (*FindConfigEnableKeyspaceColumnFamilyMetricsReader) ReadResponse ¶

func (o *FindConfigEnableKeyspaceColumnFamilyMetricsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEnableShardAwareDriversDefault ¶

type FindConfigEnableShardAwareDriversDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableShardAwareDriversDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableShardAwareDriversDefault ¶

func NewFindConfigEnableShardAwareDriversDefault(code int) *FindConfigEnableShardAwareDriversDefault

NewFindConfigEnableShardAwareDriversDefault creates a FindConfigEnableShardAwareDriversDefault with default headers values

func (*FindConfigEnableShardAwareDriversDefault) Code ¶

Code gets the status code for the find config enable shard aware drivers default response

func (*FindConfigEnableShardAwareDriversDefault) Error ¶

func (*FindConfigEnableShardAwareDriversDefault) GetPayload ¶

type FindConfigEnableShardAwareDriversOK ¶

type FindConfigEnableShardAwareDriversOK struct {
	Payload bool
}

FindConfigEnableShardAwareDriversOK handles this case with default header values.

Config value

func NewFindConfigEnableShardAwareDriversOK ¶

func NewFindConfigEnableShardAwareDriversOK() *FindConfigEnableShardAwareDriversOK

NewFindConfigEnableShardAwareDriversOK creates a FindConfigEnableShardAwareDriversOK with default headers values

func (*FindConfigEnableShardAwareDriversOK) GetPayload ¶

func (o *FindConfigEnableShardAwareDriversOK) GetPayload() bool

type FindConfigEnableShardAwareDriversParams ¶

type FindConfigEnableShardAwareDriversParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableShardAwareDriversParams contains all the parameters to send to the API endpoint for the find config enable shard aware drivers operation typically these are written to a http.Request

func NewFindConfigEnableShardAwareDriversParams ¶

func NewFindConfigEnableShardAwareDriversParams() *FindConfigEnableShardAwareDriversParams

NewFindConfigEnableShardAwareDriversParams creates a new FindConfigEnableShardAwareDriversParams object with the default values initialized.

func NewFindConfigEnableShardAwareDriversParamsWithContext ¶

func NewFindConfigEnableShardAwareDriversParamsWithContext(ctx context.Context) *FindConfigEnableShardAwareDriversParams

NewFindConfigEnableShardAwareDriversParamsWithContext creates a new FindConfigEnableShardAwareDriversParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableShardAwareDriversParamsWithHTTPClient ¶

func NewFindConfigEnableShardAwareDriversParamsWithHTTPClient(client *http.Client) *FindConfigEnableShardAwareDriversParams

NewFindConfigEnableShardAwareDriversParamsWithHTTPClient creates a new FindConfigEnableShardAwareDriversParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableShardAwareDriversParamsWithTimeout ¶

func NewFindConfigEnableShardAwareDriversParamsWithTimeout(timeout time.Duration) *FindConfigEnableShardAwareDriversParams

NewFindConfigEnableShardAwareDriversParamsWithTimeout creates a new FindConfigEnableShardAwareDriversParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableShardAwareDriversParams) SetContext ¶

SetContext adds the context to the find config enable shard aware drivers params

func (*FindConfigEnableShardAwareDriversParams) SetHTTPClient ¶

func (o *FindConfigEnableShardAwareDriversParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config enable shard aware drivers params

func (*FindConfigEnableShardAwareDriversParams) SetTimeout ¶

func (o *FindConfigEnableShardAwareDriversParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config enable shard aware drivers params

func (*FindConfigEnableShardAwareDriversParams) WithContext ¶

WithContext adds the context to the find config enable shard aware drivers params

func (*FindConfigEnableShardAwareDriversParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable shard aware drivers params

func (*FindConfigEnableShardAwareDriversParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable shard aware drivers params

func (*FindConfigEnableShardAwareDriversParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableShardAwareDriversReader ¶

type FindConfigEnableShardAwareDriversReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableShardAwareDriversReader is a Reader for the FindConfigEnableShardAwareDrivers structure.

func (*FindConfigEnableShardAwareDriversReader) ReadResponse ¶

func (o *FindConfigEnableShardAwareDriversReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEnableSstableDataIntegrityCheckDefault ¶

type FindConfigEnableSstableDataIntegrityCheckDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableSstableDataIntegrityCheckDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableSstableDataIntegrityCheckDefault ¶

func NewFindConfigEnableSstableDataIntegrityCheckDefault(code int) *FindConfigEnableSstableDataIntegrityCheckDefault

NewFindConfigEnableSstableDataIntegrityCheckDefault creates a FindConfigEnableSstableDataIntegrityCheckDefault with default headers values

func (*FindConfigEnableSstableDataIntegrityCheckDefault) Code ¶

Code gets the status code for the find config enable sstable data integrity check default response

func (*FindConfigEnableSstableDataIntegrityCheckDefault) Error ¶

func (*FindConfigEnableSstableDataIntegrityCheckDefault) GetPayload ¶

type FindConfigEnableSstableDataIntegrityCheckOK ¶

type FindConfigEnableSstableDataIntegrityCheckOK struct {
	Payload bool
}

FindConfigEnableSstableDataIntegrityCheckOK handles this case with default header values.

Config value

func NewFindConfigEnableSstableDataIntegrityCheckOK ¶

func NewFindConfigEnableSstableDataIntegrityCheckOK() *FindConfigEnableSstableDataIntegrityCheckOK

NewFindConfigEnableSstableDataIntegrityCheckOK creates a FindConfigEnableSstableDataIntegrityCheckOK with default headers values

func (*FindConfigEnableSstableDataIntegrityCheckOK) GetPayload ¶

type FindConfigEnableSstableDataIntegrityCheckParams ¶

type FindConfigEnableSstableDataIntegrityCheckParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableSstableDataIntegrityCheckParams contains all the parameters to send to the API endpoint for the find config enable sstable data integrity check operation typically these are written to a http.Request

func NewFindConfigEnableSstableDataIntegrityCheckParams ¶

func NewFindConfigEnableSstableDataIntegrityCheckParams() *FindConfigEnableSstableDataIntegrityCheckParams

NewFindConfigEnableSstableDataIntegrityCheckParams creates a new FindConfigEnableSstableDataIntegrityCheckParams object with the default values initialized.

func NewFindConfigEnableSstableDataIntegrityCheckParamsWithContext ¶

func NewFindConfigEnableSstableDataIntegrityCheckParamsWithContext(ctx context.Context) *FindConfigEnableSstableDataIntegrityCheckParams

NewFindConfigEnableSstableDataIntegrityCheckParamsWithContext creates a new FindConfigEnableSstableDataIntegrityCheckParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableSstableDataIntegrityCheckParamsWithHTTPClient ¶

func NewFindConfigEnableSstableDataIntegrityCheckParamsWithHTTPClient(client *http.Client) *FindConfigEnableSstableDataIntegrityCheckParams

NewFindConfigEnableSstableDataIntegrityCheckParamsWithHTTPClient creates a new FindConfigEnableSstableDataIntegrityCheckParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableSstableDataIntegrityCheckParamsWithTimeout ¶

func NewFindConfigEnableSstableDataIntegrityCheckParamsWithTimeout(timeout time.Duration) *FindConfigEnableSstableDataIntegrityCheckParams

NewFindConfigEnableSstableDataIntegrityCheckParamsWithTimeout creates a new FindConfigEnableSstableDataIntegrityCheckParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableSstableDataIntegrityCheckParams) SetContext ¶

SetContext adds the context to the find config enable sstable data integrity check params

func (*FindConfigEnableSstableDataIntegrityCheckParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config enable sstable data integrity check params

func (*FindConfigEnableSstableDataIntegrityCheckParams) SetTimeout ¶

SetTimeout adds the timeout to the find config enable sstable data integrity check params

func (*FindConfigEnableSstableDataIntegrityCheckParams) WithContext ¶

WithContext adds the context to the find config enable sstable data integrity check params

func (*FindConfigEnableSstableDataIntegrityCheckParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable sstable data integrity check params

func (*FindConfigEnableSstableDataIntegrityCheckParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable sstable data integrity check params

func (*FindConfigEnableSstableDataIntegrityCheckParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableSstableDataIntegrityCheckReader ¶

type FindConfigEnableSstableDataIntegrityCheckReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableSstableDataIntegrityCheckReader is a Reader for the FindConfigEnableSstableDataIntegrityCheck structure.

func (*FindConfigEnableSstableDataIntegrityCheckReader) ReadResponse ¶

func (o *FindConfigEnableSstableDataIntegrityCheckReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEnableSstablesMcFormatDefault ¶

type FindConfigEnableSstablesMcFormatDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEnableSstablesMcFormatDefault handles this case with default header values.

unexpected error

func NewFindConfigEnableSstablesMcFormatDefault ¶

func NewFindConfigEnableSstablesMcFormatDefault(code int) *FindConfigEnableSstablesMcFormatDefault

NewFindConfigEnableSstablesMcFormatDefault creates a FindConfigEnableSstablesMcFormatDefault with default headers values

func (*FindConfigEnableSstablesMcFormatDefault) Code ¶

Code gets the status code for the find config enable sstables mc format default response

func (*FindConfigEnableSstablesMcFormatDefault) Error ¶

func (*FindConfigEnableSstablesMcFormatDefault) GetPayload ¶

type FindConfigEnableSstablesMcFormatOK ¶

type FindConfigEnableSstablesMcFormatOK struct {
	Payload bool
}

FindConfigEnableSstablesMcFormatOK handles this case with default header values.

Config value

func NewFindConfigEnableSstablesMcFormatOK ¶

func NewFindConfigEnableSstablesMcFormatOK() *FindConfigEnableSstablesMcFormatOK

NewFindConfigEnableSstablesMcFormatOK creates a FindConfigEnableSstablesMcFormatOK with default headers values

func (*FindConfigEnableSstablesMcFormatOK) GetPayload ¶

func (o *FindConfigEnableSstablesMcFormatOK) GetPayload() bool

type FindConfigEnableSstablesMcFormatParams ¶

type FindConfigEnableSstablesMcFormatParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEnableSstablesMcFormatParams contains all the parameters to send to the API endpoint for the find config enable sstables mc format operation typically these are written to a http.Request

func NewFindConfigEnableSstablesMcFormatParams ¶

func NewFindConfigEnableSstablesMcFormatParams() *FindConfigEnableSstablesMcFormatParams

NewFindConfigEnableSstablesMcFormatParams creates a new FindConfigEnableSstablesMcFormatParams object with the default values initialized.

func NewFindConfigEnableSstablesMcFormatParamsWithContext ¶

func NewFindConfigEnableSstablesMcFormatParamsWithContext(ctx context.Context) *FindConfigEnableSstablesMcFormatParams

NewFindConfigEnableSstablesMcFormatParamsWithContext creates a new FindConfigEnableSstablesMcFormatParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEnableSstablesMcFormatParamsWithHTTPClient ¶

func NewFindConfigEnableSstablesMcFormatParamsWithHTTPClient(client *http.Client) *FindConfigEnableSstablesMcFormatParams

NewFindConfigEnableSstablesMcFormatParamsWithHTTPClient creates a new FindConfigEnableSstablesMcFormatParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEnableSstablesMcFormatParamsWithTimeout ¶

func NewFindConfigEnableSstablesMcFormatParamsWithTimeout(timeout time.Duration) *FindConfigEnableSstablesMcFormatParams

NewFindConfigEnableSstablesMcFormatParamsWithTimeout creates a new FindConfigEnableSstablesMcFormatParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEnableSstablesMcFormatParams) SetContext ¶

SetContext adds the context to the find config enable sstables mc format params

func (*FindConfigEnableSstablesMcFormatParams) SetHTTPClient ¶

func (o *FindConfigEnableSstablesMcFormatParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config enable sstables mc format params

func (*FindConfigEnableSstablesMcFormatParams) SetTimeout ¶

func (o *FindConfigEnableSstablesMcFormatParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config enable sstables mc format params

func (*FindConfigEnableSstablesMcFormatParams) WithContext ¶

WithContext adds the context to the find config enable sstables mc format params

func (*FindConfigEnableSstablesMcFormatParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config enable sstables mc format params

func (*FindConfigEnableSstablesMcFormatParams) WithTimeout ¶

WithTimeout adds the timeout to the find config enable sstables mc format params

func (*FindConfigEnableSstablesMcFormatParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEnableSstablesMcFormatReader ¶

type FindConfigEnableSstablesMcFormatReader struct {
	// contains filtered or unexported fields
}

FindConfigEnableSstablesMcFormatReader is a Reader for the FindConfigEnableSstablesMcFormat structure.

func (*FindConfigEnableSstablesMcFormatReader) ReadResponse ¶

func (o *FindConfigEnableSstablesMcFormatReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigEndpointSnitchDefault ¶

type FindConfigEndpointSnitchDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigEndpointSnitchDefault handles this case with default header values.

unexpected error

func NewFindConfigEndpointSnitchDefault ¶

func NewFindConfigEndpointSnitchDefault(code int) *FindConfigEndpointSnitchDefault

NewFindConfigEndpointSnitchDefault creates a FindConfigEndpointSnitchDefault with default headers values

func (*FindConfigEndpointSnitchDefault) Code ¶

Code gets the status code for the find config endpoint snitch default response

func (*FindConfigEndpointSnitchDefault) Error ¶

func (*FindConfigEndpointSnitchDefault) GetPayload ¶

type FindConfigEndpointSnitchOK ¶

type FindConfigEndpointSnitchOK struct {
	Payload string
}

FindConfigEndpointSnitchOK handles this case with default header values.

Config value

func NewFindConfigEndpointSnitchOK ¶

func NewFindConfigEndpointSnitchOK() *FindConfigEndpointSnitchOK

NewFindConfigEndpointSnitchOK creates a FindConfigEndpointSnitchOK with default headers values

func (*FindConfigEndpointSnitchOK) GetPayload ¶

func (o *FindConfigEndpointSnitchOK) GetPayload() string

type FindConfigEndpointSnitchParams ¶

type FindConfigEndpointSnitchParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigEndpointSnitchParams contains all the parameters to send to the API endpoint for the find config endpoint snitch operation typically these are written to a http.Request

func NewFindConfigEndpointSnitchParams ¶

func NewFindConfigEndpointSnitchParams() *FindConfigEndpointSnitchParams

NewFindConfigEndpointSnitchParams creates a new FindConfigEndpointSnitchParams object with the default values initialized.

func NewFindConfigEndpointSnitchParamsWithContext ¶

func NewFindConfigEndpointSnitchParamsWithContext(ctx context.Context) *FindConfigEndpointSnitchParams

NewFindConfigEndpointSnitchParamsWithContext creates a new FindConfigEndpointSnitchParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigEndpointSnitchParamsWithHTTPClient ¶

func NewFindConfigEndpointSnitchParamsWithHTTPClient(client *http.Client) *FindConfigEndpointSnitchParams

NewFindConfigEndpointSnitchParamsWithHTTPClient creates a new FindConfigEndpointSnitchParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigEndpointSnitchParamsWithTimeout ¶

func NewFindConfigEndpointSnitchParamsWithTimeout(timeout time.Duration) *FindConfigEndpointSnitchParams

NewFindConfigEndpointSnitchParamsWithTimeout creates a new FindConfigEndpointSnitchParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigEndpointSnitchParams) SetContext ¶

func (o *FindConfigEndpointSnitchParams) SetContext(ctx context.Context)

SetContext adds the context to the find config endpoint snitch params

func (*FindConfigEndpointSnitchParams) SetHTTPClient ¶

func (o *FindConfigEndpointSnitchParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config endpoint snitch params

func (*FindConfigEndpointSnitchParams) SetTimeout ¶

func (o *FindConfigEndpointSnitchParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config endpoint snitch params

func (*FindConfigEndpointSnitchParams) WithContext ¶

WithContext adds the context to the find config endpoint snitch params

func (*FindConfigEndpointSnitchParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config endpoint snitch params

func (*FindConfigEndpointSnitchParams) WithTimeout ¶

WithTimeout adds the timeout to the find config endpoint snitch params

func (*FindConfigEndpointSnitchParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigEndpointSnitchReader ¶

type FindConfigEndpointSnitchReader struct {
	// contains filtered or unexported fields
}

FindConfigEndpointSnitchReader is a Reader for the FindConfigEndpointSnitch structure.

func (*FindConfigEndpointSnitchReader) ReadResponse ¶

func (o *FindConfigEndpointSnitchReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigExperimentalDefault ¶

type FindConfigExperimentalDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigExperimentalDefault handles this case with default header values.

unexpected error

func NewFindConfigExperimentalDefault ¶

func NewFindConfigExperimentalDefault(code int) *FindConfigExperimentalDefault

NewFindConfigExperimentalDefault creates a FindConfigExperimentalDefault with default headers values

func (*FindConfigExperimentalDefault) Code ¶

Code gets the status code for the find config experimental default response

func (*FindConfigExperimentalDefault) Error ¶

func (*FindConfigExperimentalDefault) GetPayload ¶

type FindConfigExperimentalOK ¶

type FindConfigExperimentalOK struct {
	Payload bool
}

FindConfigExperimentalOK handles this case with default header values.

Config value

func NewFindConfigExperimentalOK ¶

func NewFindConfigExperimentalOK() *FindConfigExperimentalOK

NewFindConfigExperimentalOK creates a FindConfigExperimentalOK with default headers values

func (*FindConfigExperimentalOK) GetPayload ¶

func (o *FindConfigExperimentalOK) GetPayload() bool

type FindConfigExperimentalParams ¶

type FindConfigExperimentalParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigExperimentalParams contains all the parameters to send to the API endpoint for the find config experimental operation typically these are written to a http.Request

func NewFindConfigExperimentalParams ¶

func NewFindConfigExperimentalParams() *FindConfigExperimentalParams

NewFindConfigExperimentalParams creates a new FindConfigExperimentalParams object with the default values initialized.

func NewFindConfigExperimentalParamsWithContext ¶

func NewFindConfigExperimentalParamsWithContext(ctx context.Context) *FindConfigExperimentalParams

NewFindConfigExperimentalParamsWithContext creates a new FindConfigExperimentalParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigExperimentalParamsWithHTTPClient ¶

func NewFindConfigExperimentalParamsWithHTTPClient(client *http.Client) *FindConfigExperimentalParams

NewFindConfigExperimentalParamsWithHTTPClient creates a new FindConfigExperimentalParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigExperimentalParamsWithTimeout ¶

func NewFindConfigExperimentalParamsWithTimeout(timeout time.Duration) *FindConfigExperimentalParams

NewFindConfigExperimentalParamsWithTimeout creates a new FindConfigExperimentalParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigExperimentalParams) SetContext ¶

func (o *FindConfigExperimentalParams) SetContext(ctx context.Context)

SetContext adds the context to the find config experimental params

func (*FindConfigExperimentalParams) SetHTTPClient ¶

func (o *FindConfigExperimentalParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config experimental params

func (*FindConfigExperimentalParams) SetTimeout ¶

func (o *FindConfigExperimentalParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config experimental params

func (*FindConfigExperimentalParams) WithContext ¶

WithContext adds the context to the find config experimental params

func (*FindConfigExperimentalParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config experimental params

func (*FindConfigExperimentalParams) WithTimeout ¶

WithTimeout adds the timeout to the find config experimental params

func (*FindConfigExperimentalParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigExperimentalReader ¶

type FindConfigExperimentalReader struct {
	// contains filtered or unexported fields
}

FindConfigExperimentalReader is a Reader for the FindConfigExperimental structure.

func (*FindConfigExperimentalReader) ReadResponse ¶

func (o *FindConfigExperimentalReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigFdInitialValueMsDefault ¶

type FindConfigFdInitialValueMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigFdInitialValueMsDefault handles this case with default header values.

unexpected error

func NewFindConfigFdInitialValueMsDefault ¶

func NewFindConfigFdInitialValueMsDefault(code int) *FindConfigFdInitialValueMsDefault

NewFindConfigFdInitialValueMsDefault creates a FindConfigFdInitialValueMsDefault with default headers values

func (*FindConfigFdInitialValueMsDefault) Code ¶

Code gets the status code for the find config fd initial value ms default response

func (*FindConfigFdInitialValueMsDefault) Error ¶

func (*FindConfigFdInitialValueMsDefault) GetPayload ¶

type FindConfigFdInitialValueMsOK ¶

type FindConfigFdInitialValueMsOK struct {
	Payload int64
}

FindConfigFdInitialValueMsOK handles this case with default header values.

Config value

func NewFindConfigFdInitialValueMsOK ¶

func NewFindConfigFdInitialValueMsOK() *FindConfigFdInitialValueMsOK

NewFindConfigFdInitialValueMsOK creates a FindConfigFdInitialValueMsOK with default headers values

func (*FindConfigFdInitialValueMsOK) GetPayload ¶

func (o *FindConfigFdInitialValueMsOK) GetPayload() int64

type FindConfigFdInitialValueMsParams ¶

type FindConfigFdInitialValueMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigFdInitialValueMsParams contains all the parameters to send to the API endpoint for the find config fd initial value ms operation typically these are written to a http.Request

func NewFindConfigFdInitialValueMsParams ¶

func NewFindConfigFdInitialValueMsParams() *FindConfigFdInitialValueMsParams

NewFindConfigFdInitialValueMsParams creates a new FindConfigFdInitialValueMsParams object with the default values initialized.

func NewFindConfigFdInitialValueMsParamsWithContext ¶

func NewFindConfigFdInitialValueMsParamsWithContext(ctx context.Context) *FindConfigFdInitialValueMsParams

NewFindConfigFdInitialValueMsParamsWithContext creates a new FindConfigFdInitialValueMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigFdInitialValueMsParamsWithHTTPClient ¶

func NewFindConfigFdInitialValueMsParamsWithHTTPClient(client *http.Client) *FindConfigFdInitialValueMsParams

NewFindConfigFdInitialValueMsParamsWithHTTPClient creates a new FindConfigFdInitialValueMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigFdInitialValueMsParamsWithTimeout ¶

func NewFindConfigFdInitialValueMsParamsWithTimeout(timeout time.Duration) *FindConfigFdInitialValueMsParams

NewFindConfigFdInitialValueMsParamsWithTimeout creates a new FindConfigFdInitialValueMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigFdInitialValueMsParams) SetContext ¶

SetContext adds the context to the find config fd initial value ms params

func (*FindConfigFdInitialValueMsParams) SetHTTPClient ¶

func (o *FindConfigFdInitialValueMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config fd initial value ms params

func (*FindConfigFdInitialValueMsParams) SetTimeout ¶

func (o *FindConfigFdInitialValueMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config fd initial value ms params

func (*FindConfigFdInitialValueMsParams) WithContext ¶

WithContext adds the context to the find config fd initial value ms params

func (*FindConfigFdInitialValueMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config fd initial value ms params

func (*FindConfigFdInitialValueMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config fd initial value ms params

func (*FindConfigFdInitialValueMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigFdInitialValueMsReader ¶

type FindConfigFdInitialValueMsReader struct {
	// contains filtered or unexported fields
}

FindConfigFdInitialValueMsReader is a Reader for the FindConfigFdInitialValueMs structure.

func (*FindConfigFdInitialValueMsReader) ReadResponse ¶

func (o *FindConfigFdInitialValueMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigFdMaxIntervalMsDefault ¶

type FindConfigFdMaxIntervalMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigFdMaxIntervalMsDefault handles this case with default header values.

unexpected error

func NewFindConfigFdMaxIntervalMsDefault ¶

func NewFindConfigFdMaxIntervalMsDefault(code int) *FindConfigFdMaxIntervalMsDefault

NewFindConfigFdMaxIntervalMsDefault creates a FindConfigFdMaxIntervalMsDefault with default headers values

func (*FindConfigFdMaxIntervalMsDefault) Code ¶

Code gets the status code for the find config fd max interval ms default response

func (*FindConfigFdMaxIntervalMsDefault) Error ¶

func (*FindConfigFdMaxIntervalMsDefault) GetPayload ¶

type FindConfigFdMaxIntervalMsOK ¶

type FindConfigFdMaxIntervalMsOK struct {
	Payload int64
}

FindConfigFdMaxIntervalMsOK handles this case with default header values.

Config value

func NewFindConfigFdMaxIntervalMsOK ¶

func NewFindConfigFdMaxIntervalMsOK() *FindConfigFdMaxIntervalMsOK

NewFindConfigFdMaxIntervalMsOK creates a FindConfigFdMaxIntervalMsOK with default headers values

func (*FindConfigFdMaxIntervalMsOK) GetPayload ¶

func (o *FindConfigFdMaxIntervalMsOK) GetPayload() int64

type FindConfigFdMaxIntervalMsParams ¶

type FindConfigFdMaxIntervalMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigFdMaxIntervalMsParams contains all the parameters to send to the API endpoint for the find config fd max interval ms operation typically these are written to a http.Request

func NewFindConfigFdMaxIntervalMsParams ¶

func NewFindConfigFdMaxIntervalMsParams() *FindConfigFdMaxIntervalMsParams

NewFindConfigFdMaxIntervalMsParams creates a new FindConfigFdMaxIntervalMsParams object with the default values initialized.

func NewFindConfigFdMaxIntervalMsParamsWithContext ¶

func NewFindConfigFdMaxIntervalMsParamsWithContext(ctx context.Context) *FindConfigFdMaxIntervalMsParams

NewFindConfigFdMaxIntervalMsParamsWithContext creates a new FindConfigFdMaxIntervalMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigFdMaxIntervalMsParamsWithHTTPClient ¶

func NewFindConfigFdMaxIntervalMsParamsWithHTTPClient(client *http.Client) *FindConfigFdMaxIntervalMsParams

NewFindConfigFdMaxIntervalMsParamsWithHTTPClient creates a new FindConfigFdMaxIntervalMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigFdMaxIntervalMsParamsWithTimeout ¶

func NewFindConfigFdMaxIntervalMsParamsWithTimeout(timeout time.Duration) *FindConfigFdMaxIntervalMsParams

NewFindConfigFdMaxIntervalMsParamsWithTimeout creates a new FindConfigFdMaxIntervalMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigFdMaxIntervalMsParams) SetContext ¶

func (o *FindConfigFdMaxIntervalMsParams) SetContext(ctx context.Context)

SetContext adds the context to the find config fd max interval ms params

func (*FindConfigFdMaxIntervalMsParams) SetHTTPClient ¶

func (o *FindConfigFdMaxIntervalMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config fd max interval ms params

func (*FindConfigFdMaxIntervalMsParams) SetTimeout ¶

func (o *FindConfigFdMaxIntervalMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config fd max interval ms params

func (*FindConfigFdMaxIntervalMsParams) WithContext ¶

WithContext adds the context to the find config fd max interval ms params

func (*FindConfigFdMaxIntervalMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config fd max interval ms params

func (*FindConfigFdMaxIntervalMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config fd max interval ms params

func (*FindConfigFdMaxIntervalMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigFdMaxIntervalMsReader ¶

type FindConfigFdMaxIntervalMsReader struct {
	// contains filtered or unexported fields
}

FindConfigFdMaxIntervalMsReader is a Reader for the FindConfigFdMaxIntervalMs structure.

func (*FindConfigFdMaxIntervalMsReader) ReadResponse ¶

func (o *FindConfigFdMaxIntervalMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigFileCacheSizeInMbDefault ¶

type FindConfigFileCacheSizeInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigFileCacheSizeInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigFileCacheSizeInMbDefault ¶

func NewFindConfigFileCacheSizeInMbDefault(code int) *FindConfigFileCacheSizeInMbDefault

NewFindConfigFileCacheSizeInMbDefault creates a FindConfigFileCacheSizeInMbDefault with default headers values

func (*FindConfigFileCacheSizeInMbDefault) Code ¶

Code gets the status code for the find config file cache size in mb default response

func (*FindConfigFileCacheSizeInMbDefault) Error ¶

func (*FindConfigFileCacheSizeInMbDefault) GetPayload ¶

type FindConfigFileCacheSizeInMbOK ¶

type FindConfigFileCacheSizeInMbOK struct {
	Payload int64
}

FindConfigFileCacheSizeInMbOK handles this case with default header values.

Config value

func NewFindConfigFileCacheSizeInMbOK ¶

func NewFindConfigFileCacheSizeInMbOK() *FindConfigFileCacheSizeInMbOK

NewFindConfigFileCacheSizeInMbOK creates a FindConfigFileCacheSizeInMbOK with default headers values

func (*FindConfigFileCacheSizeInMbOK) GetPayload ¶

func (o *FindConfigFileCacheSizeInMbOK) GetPayload() int64

type FindConfigFileCacheSizeInMbParams ¶

type FindConfigFileCacheSizeInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigFileCacheSizeInMbParams contains all the parameters to send to the API endpoint for the find config file cache size in mb operation typically these are written to a http.Request

func NewFindConfigFileCacheSizeInMbParams ¶

func NewFindConfigFileCacheSizeInMbParams() *FindConfigFileCacheSizeInMbParams

NewFindConfigFileCacheSizeInMbParams creates a new FindConfigFileCacheSizeInMbParams object with the default values initialized.

func NewFindConfigFileCacheSizeInMbParamsWithContext ¶

func NewFindConfigFileCacheSizeInMbParamsWithContext(ctx context.Context) *FindConfigFileCacheSizeInMbParams

NewFindConfigFileCacheSizeInMbParamsWithContext creates a new FindConfigFileCacheSizeInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigFileCacheSizeInMbParamsWithHTTPClient ¶

func NewFindConfigFileCacheSizeInMbParamsWithHTTPClient(client *http.Client) *FindConfigFileCacheSizeInMbParams

NewFindConfigFileCacheSizeInMbParamsWithHTTPClient creates a new FindConfigFileCacheSizeInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigFileCacheSizeInMbParamsWithTimeout ¶

func NewFindConfigFileCacheSizeInMbParamsWithTimeout(timeout time.Duration) *FindConfigFileCacheSizeInMbParams

NewFindConfigFileCacheSizeInMbParamsWithTimeout creates a new FindConfigFileCacheSizeInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigFileCacheSizeInMbParams) SetContext ¶

SetContext adds the context to the find config file cache size in mb params

func (*FindConfigFileCacheSizeInMbParams) SetHTTPClient ¶

func (o *FindConfigFileCacheSizeInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config file cache size in mb params

func (*FindConfigFileCacheSizeInMbParams) SetTimeout ¶

func (o *FindConfigFileCacheSizeInMbParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config file cache size in mb params

func (*FindConfigFileCacheSizeInMbParams) WithContext ¶

WithContext adds the context to the find config file cache size in mb params

func (*FindConfigFileCacheSizeInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config file cache size in mb params

func (*FindConfigFileCacheSizeInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config file cache size in mb params

func (*FindConfigFileCacheSizeInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigFileCacheSizeInMbReader ¶

type FindConfigFileCacheSizeInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigFileCacheSizeInMbReader is a Reader for the FindConfigFileCacheSizeInMb structure.

func (*FindConfigFileCacheSizeInMbReader) ReadResponse ¶

func (o *FindConfigFileCacheSizeInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigHintedHandoffEnabledDefault ¶

type FindConfigHintedHandoffEnabledDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigHintedHandoffEnabledDefault handles this case with default header values.

unexpected error

func NewFindConfigHintedHandoffEnabledDefault ¶

func NewFindConfigHintedHandoffEnabledDefault(code int) *FindConfigHintedHandoffEnabledDefault

NewFindConfigHintedHandoffEnabledDefault creates a FindConfigHintedHandoffEnabledDefault with default headers values

func (*FindConfigHintedHandoffEnabledDefault) Code ¶

Code gets the status code for the find config hinted handoff enabled default response

func (*FindConfigHintedHandoffEnabledDefault) Error ¶

func (*FindConfigHintedHandoffEnabledDefault) GetPayload ¶

type FindConfigHintedHandoffEnabledOK ¶

type FindConfigHintedHandoffEnabledOK struct {
	Payload string
}

FindConfigHintedHandoffEnabledOK handles this case with default header values.

Config value

func NewFindConfigHintedHandoffEnabledOK ¶

func NewFindConfigHintedHandoffEnabledOK() *FindConfigHintedHandoffEnabledOK

NewFindConfigHintedHandoffEnabledOK creates a FindConfigHintedHandoffEnabledOK with default headers values

func (*FindConfigHintedHandoffEnabledOK) GetPayload ¶

func (o *FindConfigHintedHandoffEnabledOK) GetPayload() string

type FindConfigHintedHandoffEnabledParams ¶

type FindConfigHintedHandoffEnabledParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigHintedHandoffEnabledParams contains all the parameters to send to the API endpoint for the find config hinted handoff enabled operation typically these are written to a http.Request

func NewFindConfigHintedHandoffEnabledParams ¶

func NewFindConfigHintedHandoffEnabledParams() *FindConfigHintedHandoffEnabledParams

NewFindConfigHintedHandoffEnabledParams creates a new FindConfigHintedHandoffEnabledParams object with the default values initialized.

func NewFindConfigHintedHandoffEnabledParamsWithContext ¶

func NewFindConfigHintedHandoffEnabledParamsWithContext(ctx context.Context) *FindConfigHintedHandoffEnabledParams

NewFindConfigHintedHandoffEnabledParamsWithContext creates a new FindConfigHintedHandoffEnabledParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigHintedHandoffEnabledParamsWithHTTPClient ¶

func NewFindConfigHintedHandoffEnabledParamsWithHTTPClient(client *http.Client) *FindConfigHintedHandoffEnabledParams

NewFindConfigHintedHandoffEnabledParamsWithHTTPClient creates a new FindConfigHintedHandoffEnabledParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigHintedHandoffEnabledParamsWithTimeout ¶

func NewFindConfigHintedHandoffEnabledParamsWithTimeout(timeout time.Duration) *FindConfigHintedHandoffEnabledParams

NewFindConfigHintedHandoffEnabledParamsWithTimeout creates a new FindConfigHintedHandoffEnabledParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigHintedHandoffEnabledParams) SetContext ¶

SetContext adds the context to the find config hinted handoff enabled params

func (*FindConfigHintedHandoffEnabledParams) SetHTTPClient ¶

func (o *FindConfigHintedHandoffEnabledParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config hinted handoff enabled params

func (*FindConfigHintedHandoffEnabledParams) SetTimeout ¶

func (o *FindConfigHintedHandoffEnabledParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config hinted handoff enabled params

func (*FindConfigHintedHandoffEnabledParams) WithContext ¶

WithContext adds the context to the find config hinted handoff enabled params

func (*FindConfigHintedHandoffEnabledParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config hinted handoff enabled params

func (*FindConfigHintedHandoffEnabledParams) WithTimeout ¶

WithTimeout adds the timeout to the find config hinted handoff enabled params

func (*FindConfigHintedHandoffEnabledParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigHintedHandoffEnabledReader ¶

type FindConfigHintedHandoffEnabledReader struct {
	// contains filtered or unexported fields
}

FindConfigHintedHandoffEnabledReader is a Reader for the FindConfigHintedHandoffEnabled structure.

func (*FindConfigHintedHandoffEnabledReader) ReadResponse ¶

func (o *FindConfigHintedHandoffEnabledReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigHintedHandoffThrottleInKbDefault ¶

type FindConfigHintedHandoffThrottleInKbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigHintedHandoffThrottleInKbDefault handles this case with default header values.

unexpected error

func NewFindConfigHintedHandoffThrottleInKbDefault ¶

func NewFindConfigHintedHandoffThrottleInKbDefault(code int) *FindConfigHintedHandoffThrottleInKbDefault

NewFindConfigHintedHandoffThrottleInKbDefault creates a FindConfigHintedHandoffThrottleInKbDefault with default headers values

func (*FindConfigHintedHandoffThrottleInKbDefault) Code ¶

Code gets the status code for the find config hinted handoff throttle in kb default response

func (*FindConfigHintedHandoffThrottleInKbDefault) Error ¶

func (*FindConfigHintedHandoffThrottleInKbDefault) GetPayload ¶

type FindConfigHintedHandoffThrottleInKbOK ¶

type FindConfigHintedHandoffThrottleInKbOK struct {
	Payload int64
}

FindConfigHintedHandoffThrottleInKbOK handles this case with default header values.

Config value

func NewFindConfigHintedHandoffThrottleInKbOK ¶

func NewFindConfigHintedHandoffThrottleInKbOK() *FindConfigHintedHandoffThrottleInKbOK

NewFindConfigHintedHandoffThrottleInKbOK creates a FindConfigHintedHandoffThrottleInKbOK with default headers values

func (*FindConfigHintedHandoffThrottleInKbOK) GetPayload ¶

type FindConfigHintedHandoffThrottleInKbParams ¶

type FindConfigHintedHandoffThrottleInKbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigHintedHandoffThrottleInKbParams contains all the parameters to send to the API endpoint for the find config hinted handoff throttle in kb operation typically these are written to a http.Request

func NewFindConfigHintedHandoffThrottleInKbParams ¶

func NewFindConfigHintedHandoffThrottleInKbParams() *FindConfigHintedHandoffThrottleInKbParams

NewFindConfigHintedHandoffThrottleInKbParams creates a new FindConfigHintedHandoffThrottleInKbParams object with the default values initialized.

func NewFindConfigHintedHandoffThrottleInKbParamsWithContext ¶

func NewFindConfigHintedHandoffThrottleInKbParamsWithContext(ctx context.Context) *FindConfigHintedHandoffThrottleInKbParams

NewFindConfigHintedHandoffThrottleInKbParamsWithContext creates a new FindConfigHintedHandoffThrottleInKbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigHintedHandoffThrottleInKbParamsWithHTTPClient ¶

func NewFindConfigHintedHandoffThrottleInKbParamsWithHTTPClient(client *http.Client) *FindConfigHintedHandoffThrottleInKbParams

NewFindConfigHintedHandoffThrottleInKbParamsWithHTTPClient creates a new FindConfigHintedHandoffThrottleInKbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigHintedHandoffThrottleInKbParamsWithTimeout ¶

func NewFindConfigHintedHandoffThrottleInKbParamsWithTimeout(timeout time.Duration) *FindConfigHintedHandoffThrottleInKbParams

NewFindConfigHintedHandoffThrottleInKbParamsWithTimeout creates a new FindConfigHintedHandoffThrottleInKbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigHintedHandoffThrottleInKbParams) SetContext ¶

SetContext adds the context to the find config hinted handoff throttle in kb params

func (*FindConfigHintedHandoffThrottleInKbParams) SetHTTPClient ¶

func (o *FindConfigHintedHandoffThrottleInKbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config hinted handoff throttle in kb params

func (*FindConfigHintedHandoffThrottleInKbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config hinted handoff throttle in kb params

func (*FindConfigHintedHandoffThrottleInKbParams) WithContext ¶

WithContext adds the context to the find config hinted handoff throttle in kb params

func (*FindConfigHintedHandoffThrottleInKbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config hinted handoff throttle in kb params

func (*FindConfigHintedHandoffThrottleInKbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config hinted handoff throttle in kb params

func (*FindConfigHintedHandoffThrottleInKbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigHintedHandoffThrottleInKbReader ¶

type FindConfigHintedHandoffThrottleInKbReader struct {
	// contains filtered or unexported fields
}

FindConfigHintedHandoffThrottleInKbReader is a Reader for the FindConfigHintedHandoffThrottleInKb structure.

func (*FindConfigHintedHandoffThrottleInKbReader) ReadResponse ¶

func (o *FindConfigHintedHandoffThrottleInKbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigHintsDirectoryDefault ¶

type FindConfigHintsDirectoryDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigHintsDirectoryDefault handles this case with default header values.

unexpected error

func NewFindConfigHintsDirectoryDefault ¶

func NewFindConfigHintsDirectoryDefault(code int) *FindConfigHintsDirectoryDefault

NewFindConfigHintsDirectoryDefault creates a FindConfigHintsDirectoryDefault with default headers values

func (*FindConfigHintsDirectoryDefault) Code ¶

Code gets the status code for the find config hints directory default response

func (*FindConfigHintsDirectoryDefault) Error ¶

func (*FindConfigHintsDirectoryDefault) GetPayload ¶

type FindConfigHintsDirectoryOK ¶

type FindConfigHintsDirectoryOK struct {
	Payload string
}

FindConfigHintsDirectoryOK handles this case with default header values.

Config value

func NewFindConfigHintsDirectoryOK ¶

func NewFindConfigHintsDirectoryOK() *FindConfigHintsDirectoryOK

NewFindConfigHintsDirectoryOK creates a FindConfigHintsDirectoryOK with default headers values

func (*FindConfigHintsDirectoryOK) GetPayload ¶

func (o *FindConfigHintsDirectoryOK) GetPayload() string

type FindConfigHintsDirectoryParams ¶

type FindConfigHintsDirectoryParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigHintsDirectoryParams contains all the parameters to send to the API endpoint for the find config hints directory operation typically these are written to a http.Request

func NewFindConfigHintsDirectoryParams ¶

func NewFindConfigHintsDirectoryParams() *FindConfigHintsDirectoryParams

NewFindConfigHintsDirectoryParams creates a new FindConfigHintsDirectoryParams object with the default values initialized.

func NewFindConfigHintsDirectoryParamsWithContext ¶

func NewFindConfigHintsDirectoryParamsWithContext(ctx context.Context) *FindConfigHintsDirectoryParams

NewFindConfigHintsDirectoryParamsWithContext creates a new FindConfigHintsDirectoryParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigHintsDirectoryParamsWithHTTPClient ¶

func NewFindConfigHintsDirectoryParamsWithHTTPClient(client *http.Client) *FindConfigHintsDirectoryParams

NewFindConfigHintsDirectoryParamsWithHTTPClient creates a new FindConfigHintsDirectoryParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigHintsDirectoryParamsWithTimeout ¶

func NewFindConfigHintsDirectoryParamsWithTimeout(timeout time.Duration) *FindConfigHintsDirectoryParams

NewFindConfigHintsDirectoryParamsWithTimeout creates a new FindConfigHintsDirectoryParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigHintsDirectoryParams) SetContext ¶

func (o *FindConfigHintsDirectoryParams) SetContext(ctx context.Context)

SetContext adds the context to the find config hints directory params

func (*FindConfigHintsDirectoryParams) SetHTTPClient ¶

func (o *FindConfigHintsDirectoryParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config hints directory params

func (*FindConfigHintsDirectoryParams) SetTimeout ¶

func (o *FindConfigHintsDirectoryParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config hints directory params

func (*FindConfigHintsDirectoryParams) WithContext ¶

WithContext adds the context to the find config hints directory params

func (*FindConfigHintsDirectoryParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config hints directory params

func (*FindConfigHintsDirectoryParams) WithTimeout ¶

WithTimeout adds the timeout to the find config hints directory params

func (*FindConfigHintsDirectoryParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigHintsDirectoryReader ¶

type FindConfigHintsDirectoryReader struct {
	// contains filtered or unexported fields
}

FindConfigHintsDirectoryReader is a Reader for the FindConfigHintsDirectory structure.

func (*FindConfigHintsDirectoryReader) ReadResponse ¶

func (o *FindConfigHintsDirectoryReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigInMemoryCompactionLimitInMbDefault ¶

type FindConfigInMemoryCompactionLimitInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigInMemoryCompactionLimitInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigInMemoryCompactionLimitInMbDefault ¶

func NewFindConfigInMemoryCompactionLimitInMbDefault(code int) *FindConfigInMemoryCompactionLimitInMbDefault

NewFindConfigInMemoryCompactionLimitInMbDefault creates a FindConfigInMemoryCompactionLimitInMbDefault with default headers values

func (*FindConfigInMemoryCompactionLimitInMbDefault) Code ¶

Code gets the status code for the find config in memory compaction limit in mb default response

func (*FindConfigInMemoryCompactionLimitInMbDefault) Error ¶

func (*FindConfigInMemoryCompactionLimitInMbDefault) GetPayload ¶

type FindConfigInMemoryCompactionLimitInMbOK ¶

type FindConfigInMemoryCompactionLimitInMbOK struct {
	Payload int64
}

FindConfigInMemoryCompactionLimitInMbOK handles this case with default header values.

Config value

func NewFindConfigInMemoryCompactionLimitInMbOK ¶

func NewFindConfigInMemoryCompactionLimitInMbOK() *FindConfigInMemoryCompactionLimitInMbOK

NewFindConfigInMemoryCompactionLimitInMbOK creates a FindConfigInMemoryCompactionLimitInMbOK with default headers values

func (*FindConfigInMemoryCompactionLimitInMbOK) GetPayload ¶

type FindConfigInMemoryCompactionLimitInMbParams ¶

type FindConfigInMemoryCompactionLimitInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigInMemoryCompactionLimitInMbParams contains all the parameters to send to the API endpoint for the find config in memory compaction limit in mb operation typically these are written to a http.Request

func NewFindConfigInMemoryCompactionLimitInMbParams ¶

func NewFindConfigInMemoryCompactionLimitInMbParams() *FindConfigInMemoryCompactionLimitInMbParams

NewFindConfigInMemoryCompactionLimitInMbParams creates a new FindConfigInMemoryCompactionLimitInMbParams object with the default values initialized.

func NewFindConfigInMemoryCompactionLimitInMbParamsWithContext ¶

func NewFindConfigInMemoryCompactionLimitInMbParamsWithContext(ctx context.Context) *FindConfigInMemoryCompactionLimitInMbParams

NewFindConfigInMemoryCompactionLimitInMbParamsWithContext creates a new FindConfigInMemoryCompactionLimitInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigInMemoryCompactionLimitInMbParamsWithHTTPClient ¶

func NewFindConfigInMemoryCompactionLimitInMbParamsWithHTTPClient(client *http.Client) *FindConfigInMemoryCompactionLimitInMbParams

NewFindConfigInMemoryCompactionLimitInMbParamsWithHTTPClient creates a new FindConfigInMemoryCompactionLimitInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigInMemoryCompactionLimitInMbParamsWithTimeout ¶

func NewFindConfigInMemoryCompactionLimitInMbParamsWithTimeout(timeout time.Duration) *FindConfigInMemoryCompactionLimitInMbParams

NewFindConfigInMemoryCompactionLimitInMbParamsWithTimeout creates a new FindConfigInMemoryCompactionLimitInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigInMemoryCompactionLimitInMbParams) SetContext ¶

SetContext adds the context to the find config in memory compaction limit in mb params

func (*FindConfigInMemoryCompactionLimitInMbParams) SetHTTPClient ¶

func (o *FindConfigInMemoryCompactionLimitInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config in memory compaction limit in mb params

func (*FindConfigInMemoryCompactionLimitInMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config in memory compaction limit in mb params

func (*FindConfigInMemoryCompactionLimitInMbParams) WithContext ¶

WithContext adds the context to the find config in memory compaction limit in mb params

func (*FindConfigInMemoryCompactionLimitInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config in memory compaction limit in mb params

func (*FindConfigInMemoryCompactionLimitInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config in memory compaction limit in mb params

func (*FindConfigInMemoryCompactionLimitInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigInMemoryCompactionLimitInMbReader ¶

type FindConfigInMemoryCompactionLimitInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigInMemoryCompactionLimitInMbReader is a Reader for the FindConfigInMemoryCompactionLimitInMb structure.

func (*FindConfigInMemoryCompactionLimitInMbReader) ReadResponse ¶

func (o *FindConfigInMemoryCompactionLimitInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigIncrementalBackupsDefault ¶

type FindConfigIncrementalBackupsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigIncrementalBackupsDefault handles this case with default header values.

unexpected error

func NewFindConfigIncrementalBackupsDefault ¶

func NewFindConfigIncrementalBackupsDefault(code int) *FindConfigIncrementalBackupsDefault

NewFindConfigIncrementalBackupsDefault creates a FindConfigIncrementalBackupsDefault with default headers values

func (*FindConfigIncrementalBackupsDefault) Code ¶

Code gets the status code for the find config incremental backups default response

func (*FindConfigIncrementalBackupsDefault) Error ¶

func (*FindConfigIncrementalBackupsDefault) GetPayload ¶

type FindConfigIncrementalBackupsOK ¶

type FindConfigIncrementalBackupsOK struct {
	Payload bool
}

FindConfigIncrementalBackupsOK handles this case with default header values.

Config value

func NewFindConfigIncrementalBackupsOK ¶

func NewFindConfigIncrementalBackupsOK() *FindConfigIncrementalBackupsOK

NewFindConfigIncrementalBackupsOK creates a FindConfigIncrementalBackupsOK with default headers values

func (*FindConfigIncrementalBackupsOK) GetPayload ¶

func (o *FindConfigIncrementalBackupsOK) GetPayload() bool

type FindConfigIncrementalBackupsParams ¶

type FindConfigIncrementalBackupsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigIncrementalBackupsParams contains all the parameters to send to the API endpoint for the find config incremental backups operation typically these are written to a http.Request

func NewFindConfigIncrementalBackupsParams ¶

func NewFindConfigIncrementalBackupsParams() *FindConfigIncrementalBackupsParams

NewFindConfigIncrementalBackupsParams creates a new FindConfigIncrementalBackupsParams object with the default values initialized.

func NewFindConfigIncrementalBackupsParamsWithContext ¶

func NewFindConfigIncrementalBackupsParamsWithContext(ctx context.Context) *FindConfigIncrementalBackupsParams

NewFindConfigIncrementalBackupsParamsWithContext creates a new FindConfigIncrementalBackupsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigIncrementalBackupsParamsWithHTTPClient ¶

func NewFindConfigIncrementalBackupsParamsWithHTTPClient(client *http.Client) *FindConfigIncrementalBackupsParams

NewFindConfigIncrementalBackupsParamsWithHTTPClient creates a new FindConfigIncrementalBackupsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigIncrementalBackupsParamsWithTimeout ¶

func NewFindConfigIncrementalBackupsParamsWithTimeout(timeout time.Duration) *FindConfigIncrementalBackupsParams

NewFindConfigIncrementalBackupsParamsWithTimeout creates a new FindConfigIncrementalBackupsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigIncrementalBackupsParams) SetContext ¶

SetContext adds the context to the find config incremental backups params

func (*FindConfigIncrementalBackupsParams) SetHTTPClient ¶

func (o *FindConfigIncrementalBackupsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config incremental backups params

func (*FindConfigIncrementalBackupsParams) SetTimeout ¶

func (o *FindConfigIncrementalBackupsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config incremental backups params

func (*FindConfigIncrementalBackupsParams) WithContext ¶

WithContext adds the context to the find config incremental backups params

func (*FindConfigIncrementalBackupsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config incremental backups params

func (*FindConfigIncrementalBackupsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config incremental backups params

func (*FindConfigIncrementalBackupsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigIncrementalBackupsReader ¶

type FindConfigIncrementalBackupsReader struct {
	// contains filtered or unexported fields
}

FindConfigIncrementalBackupsReader is a Reader for the FindConfigIncrementalBackups structure.

func (*FindConfigIncrementalBackupsReader) ReadResponse ¶

func (o *FindConfigIncrementalBackupsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigIndexSummaryCapacityInMbDefault ¶

type FindConfigIndexSummaryCapacityInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigIndexSummaryCapacityInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigIndexSummaryCapacityInMbDefault ¶

func NewFindConfigIndexSummaryCapacityInMbDefault(code int) *FindConfigIndexSummaryCapacityInMbDefault

NewFindConfigIndexSummaryCapacityInMbDefault creates a FindConfigIndexSummaryCapacityInMbDefault with default headers values

func (*FindConfigIndexSummaryCapacityInMbDefault) Code ¶

Code gets the status code for the find config index summary capacity in mb default response

func (*FindConfigIndexSummaryCapacityInMbDefault) Error ¶

func (*FindConfigIndexSummaryCapacityInMbDefault) GetPayload ¶

type FindConfigIndexSummaryCapacityInMbOK ¶

type FindConfigIndexSummaryCapacityInMbOK struct {
	Payload int64
}

FindConfigIndexSummaryCapacityInMbOK handles this case with default header values.

Config value

func NewFindConfigIndexSummaryCapacityInMbOK ¶

func NewFindConfigIndexSummaryCapacityInMbOK() *FindConfigIndexSummaryCapacityInMbOK

NewFindConfigIndexSummaryCapacityInMbOK creates a FindConfigIndexSummaryCapacityInMbOK with default headers values

func (*FindConfigIndexSummaryCapacityInMbOK) GetPayload ¶

type FindConfigIndexSummaryCapacityInMbParams ¶

type FindConfigIndexSummaryCapacityInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigIndexSummaryCapacityInMbParams contains all the parameters to send to the API endpoint for the find config index summary capacity in mb operation typically these are written to a http.Request

func NewFindConfigIndexSummaryCapacityInMbParams ¶

func NewFindConfigIndexSummaryCapacityInMbParams() *FindConfigIndexSummaryCapacityInMbParams

NewFindConfigIndexSummaryCapacityInMbParams creates a new FindConfigIndexSummaryCapacityInMbParams object with the default values initialized.

func NewFindConfigIndexSummaryCapacityInMbParamsWithContext ¶

func NewFindConfigIndexSummaryCapacityInMbParamsWithContext(ctx context.Context) *FindConfigIndexSummaryCapacityInMbParams

NewFindConfigIndexSummaryCapacityInMbParamsWithContext creates a new FindConfigIndexSummaryCapacityInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigIndexSummaryCapacityInMbParamsWithHTTPClient ¶

func NewFindConfigIndexSummaryCapacityInMbParamsWithHTTPClient(client *http.Client) *FindConfigIndexSummaryCapacityInMbParams

NewFindConfigIndexSummaryCapacityInMbParamsWithHTTPClient creates a new FindConfigIndexSummaryCapacityInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigIndexSummaryCapacityInMbParamsWithTimeout ¶

func NewFindConfigIndexSummaryCapacityInMbParamsWithTimeout(timeout time.Duration) *FindConfigIndexSummaryCapacityInMbParams

NewFindConfigIndexSummaryCapacityInMbParamsWithTimeout creates a new FindConfigIndexSummaryCapacityInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigIndexSummaryCapacityInMbParams) SetContext ¶

SetContext adds the context to the find config index summary capacity in mb params

func (*FindConfigIndexSummaryCapacityInMbParams) SetHTTPClient ¶

func (o *FindConfigIndexSummaryCapacityInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config index summary capacity in mb params

func (*FindConfigIndexSummaryCapacityInMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config index summary capacity in mb params

func (*FindConfigIndexSummaryCapacityInMbParams) WithContext ¶

WithContext adds the context to the find config index summary capacity in mb params

func (*FindConfigIndexSummaryCapacityInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config index summary capacity in mb params

func (*FindConfigIndexSummaryCapacityInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config index summary capacity in mb params

func (*FindConfigIndexSummaryCapacityInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigIndexSummaryCapacityInMbReader ¶

type FindConfigIndexSummaryCapacityInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigIndexSummaryCapacityInMbReader is a Reader for the FindConfigIndexSummaryCapacityInMb structure.

func (*FindConfigIndexSummaryCapacityInMbReader) ReadResponse ¶

func (o *FindConfigIndexSummaryCapacityInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigIndexSummaryResizeIntervalInMinutesDefault ¶

type FindConfigIndexSummaryResizeIntervalInMinutesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigIndexSummaryResizeIntervalInMinutesDefault handles this case with default header values.

unexpected error

func NewFindConfigIndexSummaryResizeIntervalInMinutesDefault ¶

func NewFindConfigIndexSummaryResizeIntervalInMinutesDefault(code int) *FindConfigIndexSummaryResizeIntervalInMinutesDefault

NewFindConfigIndexSummaryResizeIntervalInMinutesDefault creates a FindConfigIndexSummaryResizeIntervalInMinutesDefault with default headers values

func (*FindConfigIndexSummaryResizeIntervalInMinutesDefault) Code ¶

Code gets the status code for the find config index summary resize interval in minutes default response

func (*FindConfigIndexSummaryResizeIntervalInMinutesDefault) Error ¶

func (*FindConfigIndexSummaryResizeIntervalInMinutesDefault) GetPayload ¶

type FindConfigIndexSummaryResizeIntervalInMinutesOK ¶

type FindConfigIndexSummaryResizeIntervalInMinutesOK struct {
	Payload int64
}

FindConfigIndexSummaryResizeIntervalInMinutesOK handles this case with default header values.

Config value

func NewFindConfigIndexSummaryResizeIntervalInMinutesOK ¶

func NewFindConfigIndexSummaryResizeIntervalInMinutesOK() *FindConfigIndexSummaryResizeIntervalInMinutesOK

NewFindConfigIndexSummaryResizeIntervalInMinutesOK creates a FindConfigIndexSummaryResizeIntervalInMinutesOK with default headers values

func (*FindConfigIndexSummaryResizeIntervalInMinutesOK) GetPayload ¶

type FindConfigIndexSummaryResizeIntervalInMinutesParams ¶

type FindConfigIndexSummaryResizeIntervalInMinutesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigIndexSummaryResizeIntervalInMinutesParams contains all the parameters to send to the API endpoint for the find config index summary resize interval in minutes operation typically these are written to a http.Request

func NewFindConfigIndexSummaryResizeIntervalInMinutesParams ¶

func NewFindConfigIndexSummaryResizeIntervalInMinutesParams() *FindConfigIndexSummaryResizeIntervalInMinutesParams

NewFindConfigIndexSummaryResizeIntervalInMinutesParams creates a new FindConfigIndexSummaryResizeIntervalInMinutesParams object with the default values initialized.

func NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithContext ¶

func NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithContext(ctx context.Context) *FindConfigIndexSummaryResizeIntervalInMinutesParams

NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithContext creates a new FindConfigIndexSummaryResizeIntervalInMinutesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithHTTPClient ¶

func NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithHTTPClient(client *http.Client) *FindConfigIndexSummaryResizeIntervalInMinutesParams

NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithHTTPClient creates a new FindConfigIndexSummaryResizeIntervalInMinutesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithTimeout ¶

func NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithTimeout(timeout time.Duration) *FindConfigIndexSummaryResizeIntervalInMinutesParams

NewFindConfigIndexSummaryResizeIntervalInMinutesParamsWithTimeout creates a new FindConfigIndexSummaryResizeIntervalInMinutesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigIndexSummaryResizeIntervalInMinutesParams) SetContext ¶

SetContext adds the context to the find config index summary resize interval in minutes params

func (*FindConfigIndexSummaryResizeIntervalInMinutesParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config index summary resize interval in minutes params

func (*FindConfigIndexSummaryResizeIntervalInMinutesParams) SetTimeout ¶

SetTimeout adds the timeout to the find config index summary resize interval in minutes params

func (*FindConfigIndexSummaryResizeIntervalInMinutesParams) WithContext ¶

WithContext adds the context to the find config index summary resize interval in minutes params

func (*FindConfigIndexSummaryResizeIntervalInMinutesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config index summary resize interval in minutes params

func (*FindConfigIndexSummaryResizeIntervalInMinutesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config index summary resize interval in minutes params

func (*FindConfigIndexSummaryResizeIntervalInMinutesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigIndexSummaryResizeIntervalInMinutesReader ¶

type FindConfigIndexSummaryResizeIntervalInMinutesReader struct {
	// contains filtered or unexported fields
}

FindConfigIndexSummaryResizeIntervalInMinutesReader is a Reader for the FindConfigIndexSummaryResizeIntervalInMinutes structure.

func (*FindConfigIndexSummaryResizeIntervalInMinutesReader) ReadResponse ¶

func (o *FindConfigIndexSummaryResizeIntervalInMinutesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigInitialTokenDefault ¶

type FindConfigInitialTokenDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigInitialTokenDefault handles this case with default header values.

unexpected error

func NewFindConfigInitialTokenDefault ¶

func NewFindConfigInitialTokenDefault(code int) *FindConfigInitialTokenDefault

NewFindConfigInitialTokenDefault creates a FindConfigInitialTokenDefault with default headers values

func (*FindConfigInitialTokenDefault) Code ¶

Code gets the status code for the find config initial token default response

func (*FindConfigInitialTokenDefault) Error ¶

func (*FindConfigInitialTokenDefault) GetPayload ¶

type FindConfigInitialTokenOK ¶

type FindConfigInitialTokenOK struct {
	Payload string
}

FindConfigInitialTokenOK handles this case with default header values.

Config value

func NewFindConfigInitialTokenOK ¶

func NewFindConfigInitialTokenOK() *FindConfigInitialTokenOK

NewFindConfigInitialTokenOK creates a FindConfigInitialTokenOK with default headers values

func (*FindConfigInitialTokenOK) GetPayload ¶

func (o *FindConfigInitialTokenOK) GetPayload() string

type FindConfigInitialTokenParams ¶

type FindConfigInitialTokenParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigInitialTokenParams contains all the parameters to send to the API endpoint for the find config initial token operation typically these are written to a http.Request

func NewFindConfigInitialTokenParams ¶

func NewFindConfigInitialTokenParams() *FindConfigInitialTokenParams

NewFindConfigInitialTokenParams creates a new FindConfigInitialTokenParams object with the default values initialized.

func NewFindConfigInitialTokenParamsWithContext ¶

func NewFindConfigInitialTokenParamsWithContext(ctx context.Context) *FindConfigInitialTokenParams

NewFindConfigInitialTokenParamsWithContext creates a new FindConfigInitialTokenParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigInitialTokenParamsWithHTTPClient ¶

func NewFindConfigInitialTokenParamsWithHTTPClient(client *http.Client) *FindConfigInitialTokenParams

NewFindConfigInitialTokenParamsWithHTTPClient creates a new FindConfigInitialTokenParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigInitialTokenParamsWithTimeout ¶

func NewFindConfigInitialTokenParamsWithTimeout(timeout time.Duration) *FindConfigInitialTokenParams

NewFindConfigInitialTokenParamsWithTimeout creates a new FindConfigInitialTokenParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigInitialTokenParams) SetContext ¶

func (o *FindConfigInitialTokenParams) SetContext(ctx context.Context)

SetContext adds the context to the find config initial token params

func (*FindConfigInitialTokenParams) SetHTTPClient ¶

func (o *FindConfigInitialTokenParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config initial token params

func (*FindConfigInitialTokenParams) SetTimeout ¶

func (o *FindConfigInitialTokenParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config initial token params

func (*FindConfigInitialTokenParams) WithContext ¶

WithContext adds the context to the find config initial token params

func (*FindConfigInitialTokenParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config initial token params

func (*FindConfigInitialTokenParams) WithTimeout ¶

WithTimeout adds the timeout to the find config initial token params

func (*FindConfigInitialTokenParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigInitialTokenReader ¶

type FindConfigInitialTokenReader struct {
	// contains filtered or unexported fields
}

FindConfigInitialTokenReader is a Reader for the FindConfigInitialToken structure.

func (*FindConfigInitialTokenReader) ReadResponse ¶

func (o *FindConfigInitialTokenReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault ¶

type FindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault handles this case with default header values.

unexpected error

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault ¶

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault(code int) *FindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault

NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault creates a FindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault with default headers values

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault) Code ¶

Code gets the status code for the find config inter dc stream throughput outbound megabits per sec default response

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault) Error ¶

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecDefault) GetPayload ¶

type FindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK ¶

type FindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK struct {
	Payload int64
}

FindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK handles this case with default header values.

Config value

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK ¶

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK() *FindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK

NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK creates a FindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK with default headers values

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecOK) GetPayload ¶

type FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams ¶

type FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams contains all the parameters to send to the API endpoint for the find config inter dc stream throughput outbound megabits per sec operation typically these are written to a http.Request

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams ¶

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams() *FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams

NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams creates a new FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams object with the default values initialized.

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithContext ¶

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithContext(ctx context.Context) *FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams

NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithContext creates a new FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithHTTPClient ¶

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithHTTPClient(client *http.Client) *FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams

NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithHTTPClient creates a new FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithTimeout ¶

func NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithTimeout(timeout time.Duration) *FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams

NewFindConfigInterDcStreamThroughputOutboundMegabitsPerSecParamsWithTimeout creates a new FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams) SetContext ¶

SetContext adds the context to the find config inter dc stream throughput outbound megabits per sec params

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config inter dc stream throughput outbound megabits per sec params

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams) SetTimeout ¶

SetTimeout adds the timeout to the find config inter dc stream throughput outbound megabits per sec params

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams) WithContext ¶

WithContext adds the context to the find config inter dc stream throughput outbound megabits per sec params

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config inter dc stream throughput outbound megabits per sec params

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams) WithTimeout ¶

WithTimeout adds the timeout to the find config inter dc stream throughput outbound megabits per sec params

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigInterDcStreamThroughputOutboundMegabitsPerSecReader ¶

type FindConfigInterDcStreamThroughputOutboundMegabitsPerSecReader struct {
	// contains filtered or unexported fields
}

FindConfigInterDcStreamThroughputOutboundMegabitsPerSecReader is a Reader for the FindConfigInterDcStreamThroughputOutboundMegabitsPerSec structure.

func (*FindConfigInterDcStreamThroughputOutboundMegabitsPerSecReader) ReadResponse ¶

ReadResponse reads a server response into the received o.

type FindConfigInterDcTCPNodelayDefault ¶

type FindConfigInterDcTCPNodelayDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigInterDcTCPNodelayDefault handles this case with default header values.

unexpected error

func NewFindConfigInterDcTCPNodelayDefault ¶

func NewFindConfigInterDcTCPNodelayDefault(code int) *FindConfigInterDcTCPNodelayDefault

NewFindConfigInterDcTCPNodelayDefault creates a FindConfigInterDcTCPNodelayDefault with default headers values

func (*FindConfigInterDcTCPNodelayDefault) Code ¶

Code gets the status code for the find config inter dc tcp nodelay default response

func (*FindConfigInterDcTCPNodelayDefault) Error ¶

func (*FindConfigInterDcTCPNodelayDefault) GetPayload ¶

type FindConfigInterDcTCPNodelayOK ¶

type FindConfigInterDcTCPNodelayOK struct {
	Payload bool
}

FindConfigInterDcTCPNodelayOK handles this case with default header values.

Config value

func NewFindConfigInterDcTCPNodelayOK ¶

func NewFindConfigInterDcTCPNodelayOK() *FindConfigInterDcTCPNodelayOK

NewFindConfigInterDcTCPNodelayOK creates a FindConfigInterDcTCPNodelayOK with default headers values

func (*FindConfigInterDcTCPNodelayOK) GetPayload ¶

func (o *FindConfigInterDcTCPNodelayOK) GetPayload() bool

type FindConfigInterDcTCPNodelayParams ¶

type FindConfigInterDcTCPNodelayParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigInterDcTCPNodelayParams contains all the parameters to send to the API endpoint for the find config inter dc tcp nodelay operation typically these are written to a http.Request

func NewFindConfigInterDcTCPNodelayParams ¶

func NewFindConfigInterDcTCPNodelayParams() *FindConfigInterDcTCPNodelayParams

NewFindConfigInterDcTCPNodelayParams creates a new FindConfigInterDcTCPNodelayParams object with the default values initialized.

func NewFindConfigInterDcTCPNodelayParamsWithContext ¶

func NewFindConfigInterDcTCPNodelayParamsWithContext(ctx context.Context) *FindConfigInterDcTCPNodelayParams

NewFindConfigInterDcTCPNodelayParamsWithContext creates a new FindConfigInterDcTCPNodelayParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigInterDcTCPNodelayParamsWithHTTPClient ¶

func NewFindConfigInterDcTCPNodelayParamsWithHTTPClient(client *http.Client) *FindConfigInterDcTCPNodelayParams

NewFindConfigInterDcTCPNodelayParamsWithHTTPClient creates a new FindConfigInterDcTCPNodelayParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigInterDcTCPNodelayParamsWithTimeout ¶

func NewFindConfigInterDcTCPNodelayParamsWithTimeout(timeout time.Duration) *FindConfigInterDcTCPNodelayParams

NewFindConfigInterDcTCPNodelayParamsWithTimeout creates a new FindConfigInterDcTCPNodelayParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigInterDcTCPNodelayParams) SetContext ¶

SetContext adds the context to the find config inter dc tcp nodelay params

func (*FindConfigInterDcTCPNodelayParams) SetHTTPClient ¶

func (o *FindConfigInterDcTCPNodelayParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config inter dc tcp nodelay params

func (*FindConfigInterDcTCPNodelayParams) SetTimeout ¶

func (o *FindConfigInterDcTCPNodelayParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config inter dc tcp nodelay params

func (*FindConfigInterDcTCPNodelayParams) WithContext ¶

WithContext adds the context to the find config inter dc tcp nodelay params

func (*FindConfigInterDcTCPNodelayParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config inter dc tcp nodelay params

func (*FindConfigInterDcTCPNodelayParams) WithTimeout ¶

WithTimeout adds the timeout to the find config inter dc tcp nodelay params

func (*FindConfigInterDcTCPNodelayParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigInterDcTCPNodelayReader ¶

type FindConfigInterDcTCPNodelayReader struct {
	// contains filtered or unexported fields
}

FindConfigInterDcTCPNodelayReader is a Reader for the FindConfigInterDcTCPNodelay structure.

func (*FindConfigInterDcTCPNodelayReader) ReadResponse ¶

func (o *FindConfigInterDcTCPNodelayReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigInternodeAuthenticatorDefault ¶

type FindConfigInternodeAuthenticatorDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigInternodeAuthenticatorDefault handles this case with default header values.

unexpected error

func NewFindConfigInternodeAuthenticatorDefault ¶

func NewFindConfigInternodeAuthenticatorDefault(code int) *FindConfigInternodeAuthenticatorDefault

NewFindConfigInternodeAuthenticatorDefault creates a FindConfigInternodeAuthenticatorDefault with default headers values

func (*FindConfigInternodeAuthenticatorDefault) Code ¶

Code gets the status code for the find config internode authenticator default response

func (*FindConfigInternodeAuthenticatorDefault) Error ¶

func (*FindConfigInternodeAuthenticatorDefault) GetPayload ¶

type FindConfigInternodeAuthenticatorOK ¶

type FindConfigInternodeAuthenticatorOK struct {
	Payload string
}

FindConfigInternodeAuthenticatorOK handles this case with default header values.

Config value

func NewFindConfigInternodeAuthenticatorOK ¶

func NewFindConfigInternodeAuthenticatorOK() *FindConfigInternodeAuthenticatorOK

NewFindConfigInternodeAuthenticatorOK creates a FindConfigInternodeAuthenticatorOK with default headers values

func (*FindConfigInternodeAuthenticatorOK) GetPayload ¶

type FindConfigInternodeAuthenticatorParams ¶

type FindConfigInternodeAuthenticatorParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigInternodeAuthenticatorParams contains all the parameters to send to the API endpoint for the find config internode authenticator operation typically these are written to a http.Request

func NewFindConfigInternodeAuthenticatorParams ¶

func NewFindConfigInternodeAuthenticatorParams() *FindConfigInternodeAuthenticatorParams

NewFindConfigInternodeAuthenticatorParams creates a new FindConfigInternodeAuthenticatorParams object with the default values initialized.

func NewFindConfigInternodeAuthenticatorParamsWithContext ¶

func NewFindConfigInternodeAuthenticatorParamsWithContext(ctx context.Context) *FindConfigInternodeAuthenticatorParams

NewFindConfigInternodeAuthenticatorParamsWithContext creates a new FindConfigInternodeAuthenticatorParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigInternodeAuthenticatorParamsWithHTTPClient ¶

func NewFindConfigInternodeAuthenticatorParamsWithHTTPClient(client *http.Client) *FindConfigInternodeAuthenticatorParams

NewFindConfigInternodeAuthenticatorParamsWithHTTPClient creates a new FindConfigInternodeAuthenticatorParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigInternodeAuthenticatorParamsWithTimeout ¶

func NewFindConfigInternodeAuthenticatorParamsWithTimeout(timeout time.Duration) *FindConfigInternodeAuthenticatorParams

NewFindConfigInternodeAuthenticatorParamsWithTimeout creates a new FindConfigInternodeAuthenticatorParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigInternodeAuthenticatorParams) SetContext ¶

SetContext adds the context to the find config internode authenticator params

func (*FindConfigInternodeAuthenticatorParams) SetHTTPClient ¶

func (o *FindConfigInternodeAuthenticatorParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config internode authenticator params

func (*FindConfigInternodeAuthenticatorParams) SetTimeout ¶

func (o *FindConfigInternodeAuthenticatorParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config internode authenticator params

func (*FindConfigInternodeAuthenticatorParams) WithContext ¶

WithContext adds the context to the find config internode authenticator params

func (*FindConfigInternodeAuthenticatorParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config internode authenticator params

func (*FindConfigInternodeAuthenticatorParams) WithTimeout ¶

WithTimeout adds the timeout to the find config internode authenticator params

func (*FindConfigInternodeAuthenticatorParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigInternodeAuthenticatorReader ¶

type FindConfigInternodeAuthenticatorReader struct {
	// contains filtered or unexported fields
}

FindConfigInternodeAuthenticatorReader is a Reader for the FindConfigInternodeAuthenticator structure.

func (*FindConfigInternodeAuthenticatorReader) ReadResponse ¶

func (o *FindConfigInternodeAuthenticatorReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigInternodeCompressionDefault ¶

type FindConfigInternodeCompressionDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigInternodeCompressionDefault handles this case with default header values.

unexpected error

func NewFindConfigInternodeCompressionDefault ¶

func NewFindConfigInternodeCompressionDefault(code int) *FindConfigInternodeCompressionDefault

NewFindConfigInternodeCompressionDefault creates a FindConfigInternodeCompressionDefault with default headers values

func (*FindConfigInternodeCompressionDefault) Code ¶

Code gets the status code for the find config internode compression default response

func (*FindConfigInternodeCompressionDefault) Error ¶

func (*FindConfigInternodeCompressionDefault) GetPayload ¶

type FindConfigInternodeCompressionOK ¶

type FindConfigInternodeCompressionOK struct {
	Payload string
}

FindConfigInternodeCompressionOK handles this case with default header values.

Config value

func NewFindConfigInternodeCompressionOK ¶

func NewFindConfigInternodeCompressionOK() *FindConfigInternodeCompressionOK

NewFindConfigInternodeCompressionOK creates a FindConfigInternodeCompressionOK with default headers values

func (*FindConfigInternodeCompressionOK) GetPayload ¶

func (o *FindConfigInternodeCompressionOK) GetPayload() string

type FindConfigInternodeCompressionParams ¶

type FindConfigInternodeCompressionParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigInternodeCompressionParams contains all the parameters to send to the API endpoint for the find config internode compression operation typically these are written to a http.Request

func NewFindConfigInternodeCompressionParams ¶

func NewFindConfigInternodeCompressionParams() *FindConfigInternodeCompressionParams

NewFindConfigInternodeCompressionParams creates a new FindConfigInternodeCompressionParams object with the default values initialized.

func NewFindConfigInternodeCompressionParamsWithContext ¶

func NewFindConfigInternodeCompressionParamsWithContext(ctx context.Context) *FindConfigInternodeCompressionParams

NewFindConfigInternodeCompressionParamsWithContext creates a new FindConfigInternodeCompressionParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigInternodeCompressionParamsWithHTTPClient ¶

func NewFindConfigInternodeCompressionParamsWithHTTPClient(client *http.Client) *FindConfigInternodeCompressionParams

NewFindConfigInternodeCompressionParamsWithHTTPClient creates a new FindConfigInternodeCompressionParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigInternodeCompressionParamsWithTimeout ¶

func NewFindConfigInternodeCompressionParamsWithTimeout(timeout time.Duration) *FindConfigInternodeCompressionParams

NewFindConfigInternodeCompressionParamsWithTimeout creates a new FindConfigInternodeCompressionParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigInternodeCompressionParams) SetContext ¶

SetContext adds the context to the find config internode compression params

func (*FindConfigInternodeCompressionParams) SetHTTPClient ¶

func (o *FindConfigInternodeCompressionParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config internode compression params

func (*FindConfigInternodeCompressionParams) SetTimeout ¶

func (o *FindConfigInternodeCompressionParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config internode compression params

func (*FindConfigInternodeCompressionParams) WithContext ¶

WithContext adds the context to the find config internode compression params

func (*FindConfigInternodeCompressionParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config internode compression params

func (*FindConfigInternodeCompressionParams) WithTimeout ¶

WithTimeout adds the timeout to the find config internode compression params

func (*FindConfigInternodeCompressionParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigInternodeCompressionReader ¶

type FindConfigInternodeCompressionReader struct {
	// contains filtered or unexported fields
}

FindConfigInternodeCompressionReader is a Reader for the FindConfigInternodeCompression structure.

func (*FindConfigInternodeCompressionReader) ReadResponse ¶

func (o *FindConfigInternodeCompressionReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigInternodeRecvBuffSizeInBytesDefault ¶

type FindConfigInternodeRecvBuffSizeInBytesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigInternodeRecvBuffSizeInBytesDefault handles this case with default header values.

unexpected error

func NewFindConfigInternodeRecvBuffSizeInBytesDefault ¶

func NewFindConfigInternodeRecvBuffSizeInBytesDefault(code int) *FindConfigInternodeRecvBuffSizeInBytesDefault

NewFindConfigInternodeRecvBuffSizeInBytesDefault creates a FindConfigInternodeRecvBuffSizeInBytesDefault with default headers values

func (*FindConfigInternodeRecvBuffSizeInBytesDefault) Code ¶

Code gets the status code for the find config internode recv buff size in bytes default response

func (*FindConfigInternodeRecvBuffSizeInBytesDefault) Error ¶

func (*FindConfigInternodeRecvBuffSizeInBytesDefault) GetPayload ¶

type FindConfigInternodeRecvBuffSizeInBytesOK ¶

type FindConfigInternodeRecvBuffSizeInBytesOK struct {
	Payload int64
}

FindConfigInternodeRecvBuffSizeInBytesOK handles this case with default header values.

Config value

func NewFindConfigInternodeRecvBuffSizeInBytesOK ¶

func NewFindConfigInternodeRecvBuffSizeInBytesOK() *FindConfigInternodeRecvBuffSizeInBytesOK

NewFindConfigInternodeRecvBuffSizeInBytesOK creates a FindConfigInternodeRecvBuffSizeInBytesOK with default headers values

func (*FindConfigInternodeRecvBuffSizeInBytesOK) GetPayload ¶

type FindConfigInternodeRecvBuffSizeInBytesParams ¶

type FindConfigInternodeRecvBuffSizeInBytesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigInternodeRecvBuffSizeInBytesParams contains all the parameters to send to the API endpoint for the find config internode recv buff size in bytes operation typically these are written to a http.Request

func NewFindConfigInternodeRecvBuffSizeInBytesParams ¶

func NewFindConfigInternodeRecvBuffSizeInBytesParams() *FindConfigInternodeRecvBuffSizeInBytesParams

NewFindConfigInternodeRecvBuffSizeInBytesParams creates a new FindConfigInternodeRecvBuffSizeInBytesParams object with the default values initialized.

func NewFindConfigInternodeRecvBuffSizeInBytesParamsWithContext ¶

func NewFindConfigInternodeRecvBuffSizeInBytesParamsWithContext(ctx context.Context) *FindConfigInternodeRecvBuffSizeInBytesParams

NewFindConfigInternodeRecvBuffSizeInBytesParamsWithContext creates a new FindConfigInternodeRecvBuffSizeInBytesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigInternodeRecvBuffSizeInBytesParamsWithHTTPClient ¶

func NewFindConfigInternodeRecvBuffSizeInBytesParamsWithHTTPClient(client *http.Client) *FindConfigInternodeRecvBuffSizeInBytesParams

NewFindConfigInternodeRecvBuffSizeInBytesParamsWithHTTPClient creates a new FindConfigInternodeRecvBuffSizeInBytesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigInternodeRecvBuffSizeInBytesParamsWithTimeout ¶

func NewFindConfigInternodeRecvBuffSizeInBytesParamsWithTimeout(timeout time.Duration) *FindConfigInternodeRecvBuffSizeInBytesParams

NewFindConfigInternodeRecvBuffSizeInBytesParamsWithTimeout creates a new FindConfigInternodeRecvBuffSizeInBytesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigInternodeRecvBuffSizeInBytesParams) SetContext ¶

SetContext adds the context to the find config internode recv buff size in bytes params

func (*FindConfigInternodeRecvBuffSizeInBytesParams) SetHTTPClient ¶

func (o *FindConfigInternodeRecvBuffSizeInBytesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config internode recv buff size in bytes params

func (*FindConfigInternodeRecvBuffSizeInBytesParams) SetTimeout ¶

SetTimeout adds the timeout to the find config internode recv buff size in bytes params

func (*FindConfigInternodeRecvBuffSizeInBytesParams) WithContext ¶

WithContext adds the context to the find config internode recv buff size in bytes params

func (*FindConfigInternodeRecvBuffSizeInBytesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config internode recv buff size in bytes params

func (*FindConfigInternodeRecvBuffSizeInBytesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config internode recv buff size in bytes params

func (*FindConfigInternodeRecvBuffSizeInBytesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigInternodeRecvBuffSizeInBytesReader ¶

type FindConfigInternodeRecvBuffSizeInBytesReader struct {
	// contains filtered or unexported fields
}

FindConfigInternodeRecvBuffSizeInBytesReader is a Reader for the FindConfigInternodeRecvBuffSizeInBytes structure.

func (*FindConfigInternodeRecvBuffSizeInBytesReader) ReadResponse ¶

func (o *FindConfigInternodeRecvBuffSizeInBytesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigInternodeSendBuffSizeInBytesDefault ¶

type FindConfigInternodeSendBuffSizeInBytesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigInternodeSendBuffSizeInBytesDefault handles this case with default header values.

unexpected error

func NewFindConfigInternodeSendBuffSizeInBytesDefault ¶

func NewFindConfigInternodeSendBuffSizeInBytesDefault(code int) *FindConfigInternodeSendBuffSizeInBytesDefault

NewFindConfigInternodeSendBuffSizeInBytesDefault creates a FindConfigInternodeSendBuffSizeInBytesDefault with default headers values

func (*FindConfigInternodeSendBuffSizeInBytesDefault) Code ¶

Code gets the status code for the find config internode send buff size in bytes default response

func (*FindConfigInternodeSendBuffSizeInBytesDefault) Error ¶

func (*FindConfigInternodeSendBuffSizeInBytesDefault) GetPayload ¶

type FindConfigInternodeSendBuffSizeInBytesOK ¶

type FindConfigInternodeSendBuffSizeInBytesOK struct {
	Payload int64
}

FindConfigInternodeSendBuffSizeInBytesOK handles this case with default header values.

Config value

func NewFindConfigInternodeSendBuffSizeInBytesOK ¶

func NewFindConfigInternodeSendBuffSizeInBytesOK() *FindConfigInternodeSendBuffSizeInBytesOK

NewFindConfigInternodeSendBuffSizeInBytesOK creates a FindConfigInternodeSendBuffSizeInBytesOK with default headers values

func (*FindConfigInternodeSendBuffSizeInBytesOK) GetPayload ¶

type FindConfigInternodeSendBuffSizeInBytesParams ¶

type FindConfigInternodeSendBuffSizeInBytesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigInternodeSendBuffSizeInBytesParams contains all the parameters to send to the API endpoint for the find config internode send buff size in bytes operation typically these are written to a http.Request

func NewFindConfigInternodeSendBuffSizeInBytesParams ¶

func NewFindConfigInternodeSendBuffSizeInBytesParams() *FindConfigInternodeSendBuffSizeInBytesParams

NewFindConfigInternodeSendBuffSizeInBytesParams creates a new FindConfigInternodeSendBuffSizeInBytesParams object with the default values initialized.

func NewFindConfigInternodeSendBuffSizeInBytesParamsWithContext ¶

func NewFindConfigInternodeSendBuffSizeInBytesParamsWithContext(ctx context.Context) *FindConfigInternodeSendBuffSizeInBytesParams

NewFindConfigInternodeSendBuffSizeInBytesParamsWithContext creates a new FindConfigInternodeSendBuffSizeInBytesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigInternodeSendBuffSizeInBytesParamsWithHTTPClient ¶

func NewFindConfigInternodeSendBuffSizeInBytesParamsWithHTTPClient(client *http.Client) *FindConfigInternodeSendBuffSizeInBytesParams

NewFindConfigInternodeSendBuffSizeInBytesParamsWithHTTPClient creates a new FindConfigInternodeSendBuffSizeInBytesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigInternodeSendBuffSizeInBytesParamsWithTimeout ¶

func NewFindConfigInternodeSendBuffSizeInBytesParamsWithTimeout(timeout time.Duration) *FindConfigInternodeSendBuffSizeInBytesParams

NewFindConfigInternodeSendBuffSizeInBytesParamsWithTimeout creates a new FindConfigInternodeSendBuffSizeInBytesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigInternodeSendBuffSizeInBytesParams) SetContext ¶

SetContext adds the context to the find config internode send buff size in bytes params

func (*FindConfigInternodeSendBuffSizeInBytesParams) SetHTTPClient ¶

func (o *FindConfigInternodeSendBuffSizeInBytesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config internode send buff size in bytes params

func (*FindConfigInternodeSendBuffSizeInBytesParams) SetTimeout ¶

SetTimeout adds the timeout to the find config internode send buff size in bytes params

func (*FindConfigInternodeSendBuffSizeInBytesParams) WithContext ¶

WithContext adds the context to the find config internode send buff size in bytes params

func (*FindConfigInternodeSendBuffSizeInBytesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config internode send buff size in bytes params

func (*FindConfigInternodeSendBuffSizeInBytesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config internode send buff size in bytes params

func (*FindConfigInternodeSendBuffSizeInBytesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigInternodeSendBuffSizeInBytesReader ¶

type FindConfigInternodeSendBuffSizeInBytesReader struct {
	// contains filtered or unexported fields
}

FindConfigInternodeSendBuffSizeInBytesReader is a Reader for the FindConfigInternodeSendBuffSizeInBytes structure.

func (*FindConfigInternodeSendBuffSizeInBytesReader) ReadResponse ¶

func (o *FindConfigInternodeSendBuffSizeInBytesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigJoinRingDefault ¶

type FindConfigJoinRingDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigJoinRingDefault handles this case with default header values.

unexpected error

func NewFindConfigJoinRingDefault ¶

func NewFindConfigJoinRingDefault(code int) *FindConfigJoinRingDefault

NewFindConfigJoinRingDefault creates a FindConfigJoinRingDefault with default headers values

func (*FindConfigJoinRingDefault) Code ¶

func (o *FindConfigJoinRingDefault) Code() int

Code gets the status code for the find config join ring default response

func (*FindConfigJoinRingDefault) Error ¶

func (o *FindConfigJoinRingDefault) Error() string

func (*FindConfigJoinRingDefault) GetPayload ¶

func (o *FindConfigJoinRingDefault) GetPayload() *models.ErrorModel

type FindConfigJoinRingOK ¶

type FindConfigJoinRingOK struct {
	Payload bool
}

FindConfigJoinRingOK handles this case with default header values.

Config value

func NewFindConfigJoinRingOK ¶

func NewFindConfigJoinRingOK() *FindConfigJoinRingOK

NewFindConfigJoinRingOK creates a FindConfigJoinRingOK with default headers values

func (*FindConfigJoinRingOK) GetPayload ¶

func (o *FindConfigJoinRingOK) GetPayload() bool

type FindConfigJoinRingParams ¶

type FindConfigJoinRingParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigJoinRingParams contains all the parameters to send to the API endpoint for the find config join ring operation typically these are written to a http.Request

func NewFindConfigJoinRingParams ¶

func NewFindConfigJoinRingParams() *FindConfigJoinRingParams

NewFindConfigJoinRingParams creates a new FindConfigJoinRingParams object with the default values initialized.

func NewFindConfigJoinRingParamsWithContext ¶

func NewFindConfigJoinRingParamsWithContext(ctx context.Context) *FindConfigJoinRingParams

NewFindConfigJoinRingParamsWithContext creates a new FindConfigJoinRingParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigJoinRingParamsWithHTTPClient ¶

func NewFindConfigJoinRingParamsWithHTTPClient(client *http.Client) *FindConfigJoinRingParams

NewFindConfigJoinRingParamsWithHTTPClient creates a new FindConfigJoinRingParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigJoinRingParamsWithTimeout ¶

func NewFindConfigJoinRingParamsWithTimeout(timeout time.Duration) *FindConfigJoinRingParams

NewFindConfigJoinRingParamsWithTimeout creates a new FindConfigJoinRingParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigJoinRingParams) SetContext ¶

func (o *FindConfigJoinRingParams) SetContext(ctx context.Context)

SetContext adds the context to the find config join ring params

func (*FindConfigJoinRingParams) SetHTTPClient ¶

func (o *FindConfigJoinRingParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config join ring params

func (*FindConfigJoinRingParams) SetTimeout ¶

func (o *FindConfigJoinRingParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config join ring params

func (*FindConfigJoinRingParams) WithContext ¶

WithContext adds the context to the find config join ring params

func (*FindConfigJoinRingParams) WithHTTPClient ¶

func (o *FindConfigJoinRingParams) WithHTTPClient(client *http.Client) *FindConfigJoinRingParams

WithHTTPClient adds the HTTPClient to the find config join ring params

func (*FindConfigJoinRingParams) WithTimeout ¶

WithTimeout adds the timeout to the find config join ring params

func (*FindConfigJoinRingParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigJoinRingReader ¶

type FindConfigJoinRingReader struct {
	// contains filtered or unexported fields
}

FindConfigJoinRingReader is a Reader for the FindConfigJoinRing structure.

func (*FindConfigJoinRingReader) ReadResponse ¶

func (o *FindConfigJoinRingReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigKeyCacheKeysToSaveDefault ¶

type FindConfigKeyCacheKeysToSaveDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigKeyCacheKeysToSaveDefault handles this case with default header values.

unexpected error

func NewFindConfigKeyCacheKeysToSaveDefault ¶

func NewFindConfigKeyCacheKeysToSaveDefault(code int) *FindConfigKeyCacheKeysToSaveDefault

NewFindConfigKeyCacheKeysToSaveDefault creates a FindConfigKeyCacheKeysToSaveDefault with default headers values

func (*FindConfigKeyCacheKeysToSaveDefault) Code ¶

Code gets the status code for the find config key cache keys to save default response

func (*FindConfigKeyCacheKeysToSaveDefault) Error ¶

func (*FindConfigKeyCacheKeysToSaveDefault) GetPayload ¶

type FindConfigKeyCacheKeysToSaveOK ¶

type FindConfigKeyCacheKeysToSaveOK struct {
	Payload int64
}

FindConfigKeyCacheKeysToSaveOK handles this case with default header values.

Config value

func NewFindConfigKeyCacheKeysToSaveOK ¶

func NewFindConfigKeyCacheKeysToSaveOK() *FindConfigKeyCacheKeysToSaveOK

NewFindConfigKeyCacheKeysToSaveOK creates a FindConfigKeyCacheKeysToSaveOK with default headers values

func (*FindConfigKeyCacheKeysToSaveOK) GetPayload ¶

func (o *FindConfigKeyCacheKeysToSaveOK) GetPayload() int64

type FindConfigKeyCacheKeysToSaveParams ¶

type FindConfigKeyCacheKeysToSaveParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigKeyCacheKeysToSaveParams contains all the parameters to send to the API endpoint for the find config key cache keys to save operation typically these are written to a http.Request

func NewFindConfigKeyCacheKeysToSaveParams ¶

func NewFindConfigKeyCacheKeysToSaveParams() *FindConfigKeyCacheKeysToSaveParams

NewFindConfigKeyCacheKeysToSaveParams creates a new FindConfigKeyCacheKeysToSaveParams object with the default values initialized.

func NewFindConfigKeyCacheKeysToSaveParamsWithContext ¶

func NewFindConfigKeyCacheKeysToSaveParamsWithContext(ctx context.Context) *FindConfigKeyCacheKeysToSaveParams

NewFindConfigKeyCacheKeysToSaveParamsWithContext creates a new FindConfigKeyCacheKeysToSaveParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigKeyCacheKeysToSaveParamsWithHTTPClient ¶

func NewFindConfigKeyCacheKeysToSaveParamsWithHTTPClient(client *http.Client) *FindConfigKeyCacheKeysToSaveParams

NewFindConfigKeyCacheKeysToSaveParamsWithHTTPClient creates a new FindConfigKeyCacheKeysToSaveParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigKeyCacheKeysToSaveParamsWithTimeout ¶

func NewFindConfigKeyCacheKeysToSaveParamsWithTimeout(timeout time.Duration) *FindConfigKeyCacheKeysToSaveParams

NewFindConfigKeyCacheKeysToSaveParamsWithTimeout creates a new FindConfigKeyCacheKeysToSaveParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigKeyCacheKeysToSaveParams) SetContext ¶

SetContext adds the context to the find config key cache keys to save params

func (*FindConfigKeyCacheKeysToSaveParams) SetHTTPClient ¶

func (o *FindConfigKeyCacheKeysToSaveParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config key cache keys to save params

func (*FindConfigKeyCacheKeysToSaveParams) SetTimeout ¶

func (o *FindConfigKeyCacheKeysToSaveParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config key cache keys to save params

func (*FindConfigKeyCacheKeysToSaveParams) WithContext ¶

WithContext adds the context to the find config key cache keys to save params

func (*FindConfigKeyCacheKeysToSaveParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config key cache keys to save params

func (*FindConfigKeyCacheKeysToSaveParams) WithTimeout ¶

WithTimeout adds the timeout to the find config key cache keys to save params

func (*FindConfigKeyCacheKeysToSaveParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigKeyCacheKeysToSaveReader ¶

type FindConfigKeyCacheKeysToSaveReader struct {
	// contains filtered or unexported fields
}

FindConfigKeyCacheKeysToSaveReader is a Reader for the FindConfigKeyCacheKeysToSave structure.

func (*FindConfigKeyCacheKeysToSaveReader) ReadResponse ¶

func (o *FindConfigKeyCacheKeysToSaveReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigKeyCacheSavePeriodDefault ¶

type FindConfigKeyCacheSavePeriodDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigKeyCacheSavePeriodDefault handles this case with default header values.

unexpected error

func NewFindConfigKeyCacheSavePeriodDefault ¶

func NewFindConfigKeyCacheSavePeriodDefault(code int) *FindConfigKeyCacheSavePeriodDefault

NewFindConfigKeyCacheSavePeriodDefault creates a FindConfigKeyCacheSavePeriodDefault with default headers values

func (*FindConfigKeyCacheSavePeriodDefault) Code ¶

Code gets the status code for the find config key cache save period default response

func (*FindConfigKeyCacheSavePeriodDefault) Error ¶

func (*FindConfigKeyCacheSavePeriodDefault) GetPayload ¶

type FindConfigKeyCacheSavePeriodOK ¶

type FindConfigKeyCacheSavePeriodOK struct {
	Payload int64
}

FindConfigKeyCacheSavePeriodOK handles this case with default header values.

Config value

func NewFindConfigKeyCacheSavePeriodOK ¶

func NewFindConfigKeyCacheSavePeriodOK() *FindConfigKeyCacheSavePeriodOK

NewFindConfigKeyCacheSavePeriodOK creates a FindConfigKeyCacheSavePeriodOK with default headers values

func (*FindConfigKeyCacheSavePeriodOK) GetPayload ¶

func (o *FindConfigKeyCacheSavePeriodOK) GetPayload() int64

type FindConfigKeyCacheSavePeriodParams ¶

type FindConfigKeyCacheSavePeriodParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigKeyCacheSavePeriodParams contains all the parameters to send to the API endpoint for the find config key cache save period operation typically these are written to a http.Request

func NewFindConfigKeyCacheSavePeriodParams ¶

func NewFindConfigKeyCacheSavePeriodParams() *FindConfigKeyCacheSavePeriodParams

NewFindConfigKeyCacheSavePeriodParams creates a new FindConfigKeyCacheSavePeriodParams object with the default values initialized.

func NewFindConfigKeyCacheSavePeriodParamsWithContext ¶

func NewFindConfigKeyCacheSavePeriodParamsWithContext(ctx context.Context) *FindConfigKeyCacheSavePeriodParams

NewFindConfigKeyCacheSavePeriodParamsWithContext creates a new FindConfigKeyCacheSavePeriodParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigKeyCacheSavePeriodParamsWithHTTPClient ¶

func NewFindConfigKeyCacheSavePeriodParamsWithHTTPClient(client *http.Client) *FindConfigKeyCacheSavePeriodParams

NewFindConfigKeyCacheSavePeriodParamsWithHTTPClient creates a new FindConfigKeyCacheSavePeriodParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigKeyCacheSavePeriodParamsWithTimeout ¶

func NewFindConfigKeyCacheSavePeriodParamsWithTimeout(timeout time.Duration) *FindConfigKeyCacheSavePeriodParams

NewFindConfigKeyCacheSavePeriodParamsWithTimeout creates a new FindConfigKeyCacheSavePeriodParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigKeyCacheSavePeriodParams) SetContext ¶

SetContext adds the context to the find config key cache save period params

func (*FindConfigKeyCacheSavePeriodParams) SetHTTPClient ¶

func (o *FindConfigKeyCacheSavePeriodParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config key cache save period params

func (*FindConfigKeyCacheSavePeriodParams) SetTimeout ¶

func (o *FindConfigKeyCacheSavePeriodParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config key cache save period params

func (*FindConfigKeyCacheSavePeriodParams) WithContext ¶

WithContext adds the context to the find config key cache save period params

func (*FindConfigKeyCacheSavePeriodParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config key cache save period params

func (*FindConfigKeyCacheSavePeriodParams) WithTimeout ¶

WithTimeout adds the timeout to the find config key cache save period params

func (*FindConfigKeyCacheSavePeriodParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigKeyCacheSavePeriodReader ¶

type FindConfigKeyCacheSavePeriodReader struct {
	// contains filtered or unexported fields
}

FindConfigKeyCacheSavePeriodReader is a Reader for the FindConfigKeyCacheSavePeriod structure.

func (*FindConfigKeyCacheSavePeriodReader) ReadResponse ¶

func (o *FindConfigKeyCacheSavePeriodReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigKeyCacheSizeInMbDefault ¶

type FindConfigKeyCacheSizeInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigKeyCacheSizeInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigKeyCacheSizeInMbDefault ¶

func NewFindConfigKeyCacheSizeInMbDefault(code int) *FindConfigKeyCacheSizeInMbDefault

NewFindConfigKeyCacheSizeInMbDefault creates a FindConfigKeyCacheSizeInMbDefault with default headers values

func (*FindConfigKeyCacheSizeInMbDefault) Code ¶

Code gets the status code for the find config key cache size in mb default response

func (*FindConfigKeyCacheSizeInMbDefault) Error ¶

func (*FindConfigKeyCacheSizeInMbDefault) GetPayload ¶

type FindConfigKeyCacheSizeInMbOK ¶

type FindConfigKeyCacheSizeInMbOK struct {
	Payload int64
}

FindConfigKeyCacheSizeInMbOK handles this case with default header values.

Config value

func NewFindConfigKeyCacheSizeInMbOK ¶

func NewFindConfigKeyCacheSizeInMbOK() *FindConfigKeyCacheSizeInMbOK

NewFindConfigKeyCacheSizeInMbOK creates a FindConfigKeyCacheSizeInMbOK with default headers values

func (*FindConfigKeyCacheSizeInMbOK) GetPayload ¶

func (o *FindConfigKeyCacheSizeInMbOK) GetPayload() int64

type FindConfigKeyCacheSizeInMbParams ¶

type FindConfigKeyCacheSizeInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigKeyCacheSizeInMbParams contains all the parameters to send to the API endpoint for the find config key cache size in mb operation typically these are written to a http.Request

func NewFindConfigKeyCacheSizeInMbParams ¶

func NewFindConfigKeyCacheSizeInMbParams() *FindConfigKeyCacheSizeInMbParams

NewFindConfigKeyCacheSizeInMbParams creates a new FindConfigKeyCacheSizeInMbParams object with the default values initialized.

func NewFindConfigKeyCacheSizeInMbParamsWithContext ¶

func NewFindConfigKeyCacheSizeInMbParamsWithContext(ctx context.Context) *FindConfigKeyCacheSizeInMbParams

NewFindConfigKeyCacheSizeInMbParamsWithContext creates a new FindConfigKeyCacheSizeInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigKeyCacheSizeInMbParamsWithHTTPClient ¶

func NewFindConfigKeyCacheSizeInMbParamsWithHTTPClient(client *http.Client) *FindConfigKeyCacheSizeInMbParams

NewFindConfigKeyCacheSizeInMbParamsWithHTTPClient creates a new FindConfigKeyCacheSizeInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigKeyCacheSizeInMbParamsWithTimeout ¶

func NewFindConfigKeyCacheSizeInMbParamsWithTimeout(timeout time.Duration) *FindConfigKeyCacheSizeInMbParams

NewFindConfigKeyCacheSizeInMbParamsWithTimeout creates a new FindConfigKeyCacheSizeInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigKeyCacheSizeInMbParams) SetContext ¶

SetContext adds the context to the find config key cache size in mb params

func (*FindConfigKeyCacheSizeInMbParams) SetHTTPClient ¶

func (o *FindConfigKeyCacheSizeInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config key cache size in mb params

func (*FindConfigKeyCacheSizeInMbParams) SetTimeout ¶

func (o *FindConfigKeyCacheSizeInMbParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config key cache size in mb params

func (*FindConfigKeyCacheSizeInMbParams) WithContext ¶

WithContext adds the context to the find config key cache size in mb params

func (*FindConfigKeyCacheSizeInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config key cache size in mb params

func (*FindConfigKeyCacheSizeInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config key cache size in mb params

func (*FindConfigKeyCacheSizeInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigKeyCacheSizeInMbReader ¶

type FindConfigKeyCacheSizeInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigKeyCacheSizeInMbReader is a Reader for the FindConfigKeyCacheSizeInMb structure.

func (*FindConfigKeyCacheSizeInMbReader) ReadResponse ¶

func (o *FindConfigKeyCacheSizeInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigLargeMemoryAllocationWarningThresholdDefault ¶

type FindConfigLargeMemoryAllocationWarningThresholdDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigLargeMemoryAllocationWarningThresholdDefault handles this case with default header values.

unexpected error

func NewFindConfigLargeMemoryAllocationWarningThresholdDefault ¶

func NewFindConfigLargeMemoryAllocationWarningThresholdDefault(code int) *FindConfigLargeMemoryAllocationWarningThresholdDefault

NewFindConfigLargeMemoryAllocationWarningThresholdDefault creates a FindConfigLargeMemoryAllocationWarningThresholdDefault with default headers values

func (*FindConfigLargeMemoryAllocationWarningThresholdDefault) Code ¶

Code gets the status code for the find config large memory allocation warning threshold default response

func (*FindConfigLargeMemoryAllocationWarningThresholdDefault) Error ¶

func (*FindConfigLargeMemoryAllocationWarningThresholdDefault) GetPayload ¶

type FindConfigLargeMemoryAllocationWarningThresholdOK ¶

type FindConfigLargeMemoryAllocationWarningThresholdOK struct {
	Payload int64
}

FindConfigLargeMemoryAllocationWarningThresholdOK handles this case with default header values.

Config value

func NewFindConfigLargeMemoryAllocationWarningThresholdOK ¶

func NewFindConfigLargeMemoryAllocationWarningThresholdOK() *FindConfigLargeMemoryAllocationWarningThresholdOK

NewFindConfigLargeMemoryAllocationWarningThresholdOK creates a FindConfigLargeMemoryAllocationWarningThresholdOK with default headers values

func (*FindConfigLargeMemoryAllocationWarningThresholdOK) GetPayload ¶

type FindConfigLargeMemoryAllocationWarningThresholdParams ¶

type FindConfigLargeMemoryAllocationWarningThresholdParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigLargeMemoryAllocationWarningThresholdParams contains all the parameters to send to the API endpoint for the find config large memory allocation warning threshold operation typically these are written to a http.Request

func NewFindConfigLargeMemoryAllocationWarningThresholdParams ¶

func NewFindConfigLargeMemoryAllocationWarningThresholdParams() *FindConfigLargeMemoryAllocationWarningThresholdParams

NewFindConfigLargeMemoryAllocationWarningThresholdParams creates a new FindConfigLargeMemoryAllocationWarningThresholdParams object with the default values initialized.

func NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithContext ¶

func NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithContext(ctx context.Context) *FindConfigLargeMemoryAllocationWarningThresholdParams

NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithContext creates a new FindConfigLargeMemoryAllocationWarningThresholdParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithHTTPClient ¶

func NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithHTTPClient(client *http.Client) *FindConfigLargeMemoryAllocationWarningThresholdParams

NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithHTTPClient creates a new FindConfigLargeMemoryAllocationWarningThresholdParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithTimeout ¶

func NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithTimeout(timeout time.Duration) *FindConfigLargeMemoryAllocationWarningThresholdParams

NewFindConfigLargeMemoryAllocationWarningThresholdParamsWithTimeout creates a new FindConfigLargeMemoryAllocationWarningThresholdParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigLargeMemoryAllocationWarningThresholdParams) SetContext ¶

SetContext adds the context to the find config large memory allocation warning threshold params

func (*FindConfigLargeMemoryAllocationWarningThresholdParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config large memory allocation warning threshold params

func (*FindConfigLargeMemoryAllocationWarningThresholdParams) SetTimeout ¶

SetTimeout adds the timeout to the find config large memory allocation warning threshold params

func (*FindConfigLargeMemoryAllocationWarningThresholdParams) WithContext ¶

WithContext adds the context to the find config large memory allocation warning threshold params

func (*FindConfigLargeMemoryAllocationWarningThresholdParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config large memory allocation warning threshold params

func (*FindConfigLargeMemoryAllocationWarningThresholdParams) WithTimeout ¶

WithTimeout adds the timeout to the find config large memory allocation warning threshold params

func (*FindConfigLargeMemoryAllocationWarningThresholdParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigLargeMemoryAllocationWarningThresholdReader ¶

type FindConfigLargeMemoryAllocationWarningThresholdReader struct {
	// contains filtered or unexported fields
}

FindConfigLargeMemoryAllocationWarningThresholdReader is a Reader for the FindConfigLargeMemoryAllocationWarningThreshold structure.

func (*FindConfigLargeMemoryAllocationWarningThresholdReader) ReadResponse ¶

func (o *FindConfigLargeMemoryAllocationWarningThresholdReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigListenAddressDefault ¶

type FindConfigListenAddressDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigListenAddressDefault handles this case with default header values.

unexpected error

func NewFindConfigListenAddressDefault ¶

func NewFindConfigListenAddressDefault(code int) *FindConfigListenAddressDefault

NewFindConfigListenAddressDefault creates a FindConfigListenAddressDefault with default headers values

func (*FindConfigListenAddressDefault) Code ¶

Code gets the status code for the find config listen address default response

func (*FindConfigListenAddressDefault) Error ¶

func (*FindConfigListenAddressDefault) GetPayload ¶

type FindConfigListenAddressOK ¶

type FindConfigListenAddressOK struct {
	Payload string
}

FindConfigListenAddressOK handles this case with default header values.

Config value

func NewFindConfigListenAddressOK ¶

func NewFindConfigListenAddressOK() *FindConfigListenAddressOK

NewFindConfigListenAddressOK creates a FindConfigListenAddressOK with default headers values

func (*FindConfigListenAddressOK) GetPayload ¶

func (o *FindConfigListenAddressOK) GetPayload() string

type FindConfigListenAddressParams ¶

type FindConfigListenAddressParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigListenAddressParams contains all the parameters to send to the API endpoint for the find config listen address operation typically these are written to a http.Request

func NewFindConfigListenAddressParams ¶

func NewFindConfigListenAddressParams() *FindConfigListenAddressParams

NewFindConfigListenAddressParams creates a new FindConfigListenAddressParams object with the default values initialized.

func NewFindConfigListenAddressParamsWithContext ¶

func NewFindConfigListenAddressParamsWithContext(ctx context.Context) *FindConfigListenAddressParams

NewFindConfigListenAddressParamsWithContext creates a new FindConfigListenAddressParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigListenAddressParamsWithHTTPClient ¶

func NewFindConfigListenAddressParamsWithHTTPClient(client *http.Client) *FindConfigListenAddressParams

NewFindConfigListenAddressParamsWithHTTPClient creates a new FindConfigListenAddressParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigListenAddressParamsWithTimeout ¶

func NewFindConfigListenAddressParamsWithTimeout(timeout time.Duration) *FindConfigListenAddressParams

NewFindConfigListenAddressParamsWithTimeout creates a new FindConfigListenAddressParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigListenAddressParams) SetContext ¶

func (o *FindConfigListenAddressParams) SetContext(ctx context.Context)

SetContext adds the context to the find config listen address params

func (*FindConfigListenAddressParams) SetHTTPClient ¶

func (o *FindConfigListenAddressParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config listen address params

func (*FindConfigListenAddressParams) SetTimeout ¶

func (o *FindConfigListenAddressParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config listen address params

func (*FindConfigListenAddressParams) WithContext ¶

WithContext adds the context to the find config listen address params

func (*FindConfigListenAddressParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config listen address params

func (*FindConfigListenAddressParams) WithTimeout ¶

WithTimeout adds the timeout to the find config listen address params

func (*FindConfigListenAddressParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigListenAddressReader ¶

type FindConfigListenAddressReader struct {
	// contains filtered or unexported fields
}

FindConfigListenAddressReader is a Reader for the FindConfigListenAddress structure.

func (*FindConfigListenAddressReader) ReadResponse ¶

func (o *FindConfigListenAddressReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigListenInterfaceDefault ¶

type FindConfigListenInterfaceDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigListenInterfaceDefault handles this case with default header values.

unexpected error

func NewFindConfigListenInterfaceDefault ¶

func NewFindConfigListenInterfaceDefault(code int) *FindConfigListenInterfaceDefault

NewFindConfigListenInterfaceDefault creates a FindConfigListenInterfaceDefault with default headers values

func (*FindConfigListenInterfaceDefault) Code ¶

Code gets the status code for the find config listen interface default response

func (*FindConfigListenInterfaceDefault) Error ¶

func (*FindConfigListenInterfaceDefault) GetPayload ¶

type FindConfigListenInterfaceOK ¶

type FindConfigListenInterfaceOK struct {
	Payload string
}

FindConfigListenInterfaceOK handles this case with default header values.

Config value

func NewFindConfigListenInterfaceOK ¶

func NewFindConfigListenInterfaceOK() *FindConfigListenInterfaceOK

NewFindConfigListenInterfaceOK creates a FindConfigListenInterfaceOK with default headers values

func (*FindConfigListenInterfaceOK) GetPayload ¶

func (o *FindConfigListenInterfaceOK) GetPayload() string

type FindConfigListenInterfaceParams ¶

type FindConfigListenInterfaceParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigListenInterfaceParams contains all the parameters to send to the API endpoint for the find config listen interface operation typically these are written to a http.Request

func NewFindConfigListenInterfaceParams ¶

func NewFindConfigListenInterfaceParams() *FindConfigListenInterfaceParams

NewFindConfigListenInterfaceParams creates a new FindConfigListenInterfaceParams object with the default values initialized.

func NewFindConfigListenInterfaceParamsWithContext ¶

func NewFindConfigListenInterfaceParamsWithContext(ctx context.Context) *FindConfigListenInterfaceParams

NewFindConfigListenInterfaceParamsWithContext creates a new FindConfigListenInterfaceParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigListenInterfaceParamsWithHTTPClient ¶

func NewFindConfigListenInterfaceParamsWithHTTPClient(client *http.Client) *FindConfigListenInterfaceParams

NewFindConfigListenInterfaceParamsWithHTTPClient creates a new FindConfigListenInterfaceParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigListenInterfaceParamsWithTimeout ¶

func NewFindConfigListenInterfaceParamsWithTimeout(timeout time.Duration) *FindConfigListenInterfaceParams

NewFindConfigListenInterfaceParamsWithTimeout creates a new FindConfigListenInterfaceParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigListenInterfaceParams) SetContext ¶

func (o *FindConfigListenInterfaceParams) SetContext(ctx context.Context)

SetContext adds the context to the find config listen interface params

func (*FindConfigListenInterfaceParams) SetHTTPClient ¶

func (o *FindConfigListenInterfaceParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config listen interface params

func (*FindConfigListenInterfaceParams) SetTimeout ¶

func (o *FindConfigListenInterfaceParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config listen interface params

func (*FindConfigListenInterfaceParams) WithContext ¶

WithContext adds the context to the find config listen interface params

func (*FindConfigListenInterfaceParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config listen interface params

func (*FindConfigListenInterfaceParams) WithTimeout ¶

WithTimeout adds the timeout to the find config listen interface params

func (*FindConfigListenInterfaceParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigListenInterfaceReader ¶

type FindConfigListenInterfaceReader struct {
	// contains filtered or unexported fields
}

FindConfigListenInterfaceReader is a Reader for the FindConfigListenInterface structure.

func (*FindConfigListenInterfaceReader) ReadResponse ¶

func (o *FindConfigListenInterfaceReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigListenOnBroadcastAddressDefault ¶

type FindConfigListenOnBroadcastAddressDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigListenOnBroadcastAddressDefault handles this case with default header values.

unexpected error

func NewFindConfigListenOnBroadcastAddressDefault ¶

func NewFindConfigListenOnBroadcastAddressDefault(code int) *FindConfigListenOnBroadcastAddressDefault

NewFindConfigListenOnBroadcastAddressDefault creates a FindConfigListenOnBroadcastAddressDefault with default headers values

func (*FindConfigListenOnBroadcastAddressDefault) Code ¶

Code gets the status code for the find config listen on broadcast address default response

func (*FindConfigListenOnBroadcastAddressDefault) Error ¶

func (*FindConfigListenOnBroadcastAddressDefault) GetPayload ¶

type FindConfigListenOnBroadcastAddressOK ¶

type FindConfigListenOnBroadcastAddressOK struct {
	Payload bool
}

FindConfigListenOnBroadcastAddressOK handles this case with default header values.

Config value

func NewFindConfigListenOnBroadcastAddressOK ¶

func NewFindConfigListenOnBroadcastAddressOK() *FindConfigListenOnBroadcastAddressOK

NewFindConfigListenOnBroadcastAddressOK creates a FindConfigListenOnBroadcastAddressOK with default headers values

func (*FindConfigListenOnBroadcastAddressOK) GetPayload ¶

type FindConfigListenOnBroadcastAddressParams ¶

type FindConfigListenOnBroadcastAddressParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigListenOnBroadcastAddressParams contains all the parameters to send to the API endpoint for the find config listen on broadcast address operation typically these are written to a http.Request

func NewFindConfigListenOnBroadcastAddressParams ¶

func NewFindConfigListenOnBroadcastAddressParams() *FindConfigListenOnBroadcastAddressParams

NewFindConfigListenOnBroadcastAddressParams creates a new FindConfigListenOnBroadcastAddressParams object with the default values initialized.

func NewFindConfigListenOnBroadcastAddressParamsWithContext ¶

func NewFindConfigListenOnBroadcastAddressParamsWithContext(ctx context.Context) *FindConfigListenOnBroadcastAddressParams

NewFindConfigListenOnBroadcastAddressParamsWithContext creates a new FindConfigListenOnBroadcastAddressParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigListenOnBroadcastAddressParamsWithHTTPClient ¶

func NewFindConfigListenOnBroadcastAddressParamsWithHTTPClient(client *http.Client) *FindConfigListenOnBroadcastAddressParams

NewFindConfigListenOnBroadcastAddressParamsWithHTTPClient creates a new FindConfigListenOnBroadcastAddressParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigListenOnBroadcastAddressParamsWithTimeout ¶

func NewFindConfigListenOnBroadcastAddressParamsWithTimeout(timeout time.Duration) *FindConfigListenOnBroadcastAddressParams

NewFindConfigListenOnBroadcastAddressParamsWithTimeout creates a new FindConfigListenOnBroadcastAddressParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigListenOnBroadcastAddressParams) SetContext ¶

SetContext adds the context to the find config listen on broadcast address params

func (*FindConfigListenOnBroadcastAddressParams) SetHTTPClient ¶

func (o *FindConfigListenOnBroadcastAddressParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config listen on broadcast address params

func (*FindConfigListenOnBroadcastAddressParams) SetTimeout ¶

SetTimeout adds the timeout to the find config listen on broadcast address params

func (*FindConfigListenOnBroadcastAddressParams) WithContext ¶

WithContext adds the context to the find config listen on broadcast address params

func (*FindConfigListenOnBroadcastAddressParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config listen on broadcast address params

func (*FindConfigListenOnBroadcastAddressParams) WithTimeout ¶

WithTimeout adds the timeout to the find config listen on broadcast address params

func (*FindConfigListenOnBroadcastAddressParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigListenOnBroadcastAddressReader ¶

type FindConfigListenOnBroadcastAddressReader struct {
	// contains filtered or unexported fields
}

FindConfigListenOnBroadcastAddressReader is a Reader for the FindConfigListenOnBroadcastAddress structure.

func (*FindConfigListenOnBroadcastAddressReader) ReadResponse ¶

func (o *FindConfigListenOnBroadcastAddressReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigLoadBalanceDefault ¶

type FindConfigLoadBalanceDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigLoadBalanceDefault handles this case with default header values.

unexpected error

func NewFindConfigLoadBalanceDefault ¶

func NewFindConfigLoadBalanceDefault(code int) *FindConfigLoadBalanceDefault

NewFindConfigLoadBalanceDefault creates a FindConfigLoadBalanceDefault with default headers values

func (*FindConfigLoadBalanceDefault) Code ¶

Code gets the status code for the find config load balance default response

func (*FindConfigLoadBalanceDefault) Error ¶

func (*FindConfigLoadBalanceDefault) GetPayload ¶

type FindConfigLoadBalanceOK ¶

type FindConfigLoadBalanceOK struct {
	Payload string
}

FindConfigLoadBalanceOK handles this case with default header values.

Config value

func NewFindConfigLoadBalanceOK ¶

func NewFindConfigLoadBalanceOK() *FindConfigLoadBalanceOK

NewFindConfigLoadBalanceOK creates a FindConfigLoadBalanceOK with default headers values

func (*FindConfigLoadBalanceOK) GetPayload ¶

func (o *FindConfigLoadBalanceOK) GetPayload() string

type FindConfigLoadBalanceParams ¶

type FindConfigLoadBalanceParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigLoadBalanceParams contains all the parameters to send to the API endpoint for the find config load balance operation typically these are written to a http.Request

func NewFindConfigLoadBalanceParams ¶

func NewFindConfigLoadBalanceParams() *FindConfigLoadBalanceParams

NewFindConfigLoadBalanceParams creates a new FindConfigLoadBalanceParams object with the default values initialized.

func NewFindConfigLoadBalanceParamsWithContext ¶

func NewFindConfigLoadBalanceParamsWithContext(ctx context.Context) *FindConfigLoadBalanceParams

NewFindConfigLoadBalanceParamsWithContext creates a new FindConfigLoadBalanceParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigLoadBalanceParamsWithHTTPClient ¶

func NewFindConfigLoadBalanceParamsWithHTTPClient(client *http.Client) *FindConfigLoadBalanceParams

NewFindConfigLoadBalanceParamsWithHTTPClient creates a new FindConfigLoadBalanceParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigLoadBalanceParamsWithTimeout ¶

func NewFindConfigLoadBalanceParamsWithTimeout(timeout time.Duration) *FindConfigLoadBalanceParams

NewFindConfigLoadBalanceParamsWithTimeout creates a new FindConfigLoadBalanceParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigLoadBalanceParams) SetContext ¶

func (o *FindConfigLoadBalanceParams) SetContext(ctx context.Context)

SetContext adds the context to the find config load balance params

func (*FindConfigLoadBalanceParams) SetHTTPClient ¶

func (o *FindConfigLoadBalanceParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config load balance params

func (*FindConfigLoadBalanceParams) SetTimeout ¶

func (o *FindConfigLoadBalanceParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config load balance params

func (*FindConfigLoadBalanceParams) WithContext ¶

WithContext adds the context to the find config load balance params

func (*FindConfigLoadBalanceParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config load balance params

func (*FindConfigLoadBalanceParams) WithTimeout ¶

WithTimeout adds the timeout to the find config load balance params

func (*FindConfigLoadBalanceParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigLoadBalanceReader ¶

type FindConfigLoadBalanceReader struct {
	// contains filtered or unexported fields
}

FindConfigLoadBalanceReader is a Reader for the FindConfigLoadBalance structure.

func (*FindConfigLoadBalanceReader) ReadResponse ¶

func (o *FindConfigLoadBalanceReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigLoadRingStateDefault ¶

type FindConfigLoadRingStateDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigLoadRingStateDefault handles this case with default header values.

unexpected error

func NewFindConfigLoadRingStateDefault ¶

func NewFindConfigLoadRingStateDefault(code int) *FindConfigLoadRingStateDefault

NewFindConfigLoadRingStateDefault creates a FindConfigLoadRingStateDefault with default headers values

func (*FindConfigLoadRingStateDefault) Code ¶

Code gets the status code for the find config load ring state default response

func (*FindConfigLoadRingStateDefault) Error ¶

func (*FindConfigLoadRingStateDefault) GetPayload ¶

type FindConfigLoadRingStateOK ¶

type FindConfigLoadRingStateOK struct {
	Payload bool
}

FindConfigLoadRingStateOK handles this case with default header values.

Config value

func NewFindConfigLoadRingStateOK ¶

func NewFindConfigLoadRingStateOK() *FindConfigLoadRingStateOK

NewFindConfigLoadRingStateOK creates a FindConfigLoadRingStateOK with default headers values

func (*FindConfigLoadRingStateOK) GetPayload ¶

func (o *FindConfigLoadRingStateOK) GetPayload() bool

type FindConfigLoadRingStateParams ¶

type FindConfigLoadRingStateParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigLoadRingStateParams contains all the parameters to send to the API endpoint for the find config load ring state operation typically these are written to a http.Request

func NewFindConfigLoadRingStateParams ¶

func NewFindConfigLoadRingStateParams() *FindConfigLoadRingStateParams

NewFindConfigLoadRingStateParams creates a new FindConfigLoadRingStateParams object with the default values initialized.

func NewFindConfigLoadRingStateParamsWithContext ¶

func NewFindConfigLoadRingStateParamsWithContext(ctx context.Context) *FindConfigLoadRingStateParams

NewFindConfigLoadRingStateParamsWithContext creates a new FindConfigLoadRingStateParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigLoadRingStateParamsWithHTTPClient ¶

func NewFindConfigLoadRingStateParamsWithHTTPClient(client *http.Client) *FindConfigLoadRingStateParams

NewFindConfigLoadRingStateParamsWithHTTPClient creates a new FindConfigLoadRingStateParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigLoadRingStateParamsWithTimeout ¶

func NewFindConfigLoadRingStateParamsWithTimeout(timeout time.Duration) *FindConfigLoadRingStateParams

NewFindConfigLoadRingStateParamsWithTimeout creates a new FindConfigLoadRingStateParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigLoadRingStateParams) SetContext ¶

func (o *FindConfigLoadRingStateParams) SetContext(ctx context.Context)

SetContext adds the context to the find config load ring state params

func (*FindConfigLoadRingStateParams) SetHTTPClient ¶

func (o *FindConfigLoadRingStateParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config load ring state params

func (*FindConfigLoadRingStateParams) SetTimeout ¶

func (o *FindConfigLoadRingStateParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config load ring state params

func (*FindConfigLoadRingStateParams) WithContext ¶

WithContext adds the context to the find config load ring state params

func (*FindConfigLoadRingStateParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config load ring state params

func (*FindConfigLoadRingStateParams) WithTimeout ¶

WithTimeout adds the timeout to the find config load ring state params

func (*FindConfigLoadRingStateParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigLoadRingStateReader ¶

type FindConfigLoadRingStateReader struct {
	// contains filtered or unexported fields
}

FindConfigLoadRingStateReader is a Reader for the FindConfigLoadRingState structure.

func (*FindConfigLoadRingStateReader) ReadResponse ¶

func (o *FindConfigLoadRingStateReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigLogToStdoutDefault ¶

type FindConfigLogToStdoutDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigLogToStdoutDefault handles this case with default header values.

unexpected error

func NewFindConfigLogToStdoutDefault ¶

func NewFindConfigLogToStdoutDefault(code int) *FindConfigLogToStdoutDefault

NewFindConfigLogToStdoutDefault creates a FindConfigLogToStdoutDefault with default headers values

func (*FindConfigLogToStdoutDefault) Code ¶

Code gets the status code for the find config log to stdout default response

func (*FindConfigLogToStdoutDefault) Error ¶

func (*FindConfigLogToStdoutDefault) GetPayload ¶

type FindConfigLogToStdoutOK ¶

type FindConfigLogToStdoutOK struct {
	Payload bool
}

FindConfigLogToStdoutOK handles this case with default header values.

Config value

func NewFindConfigLogToStdoutOK ¶

func NewFindConfigLogToStdoutOK() *FindConfigLogToStdoutOK

NewFindConfigLogToStdoutOK creates a FindConfigLogToStdoutOK with default headers values

func (*FindConfigLogToStdoutOK) GetPayload ¶

func (o *FindConfigLogToStdoutOK) GetPayload() bool

type FindConfigLogToStdoutParams ¶

type FindConfigLogToStdoutParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigLogToStdoutParams contains all the parameters to send to the API endpoint for the find config log to stdout operation typically these are written to a http.Request

func NewFindConfigLogToStdoutParams ¶

func NewFindConfigLogToStdoutParams() *FindConfigLogToStdoutParams

NewFindConfigLogToStdoutParams creates a new FindConfigLogToStdoutParams object with the default values initialized.

func NewFindConfigLogToStdoutParamsWithContext ¶

func NewFindConfigLogToStdoutParamsWithContext(ctx context.Context) *FindConfigLogToStdoutParams

NewFindConfigLogToStdoutParamsWithContext creates a new FindConfigLogToStdoutParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigLogToStdoutParamsWithHTTPClient ¶

func NewFindConfigLogToStdoutParamsWithHTTPClient(client *http.Client) *FindConfigLogToStdoutParams

NewFindConfigLogToStdoutParamsWithHTTPClient creates a new FindConfigLogToStdoutParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigLogToStdoutParamsWithTimeout ¶

func NewFindConfigLogToStdoutParamsWithTimeout(timeout time.Duration) *FindConfigLogToStdoutParams

NewFindConfigLogToStdoutParamsWithTimeout creates a new FindConfigLogToStdoutParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigLogToStdoutParams) SetContext ¶

func (o *FindConfigLogToStdoutParams) SetContext(ctx context.Context)

SetContext adds the context to the find config log to stdout params

func (*FindConfigLogToStdoutParams) SetHTTPClient ¶

func (o *FindConfigLogToStdoutParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config log to stdout params

func (*FindConfigLogToStdoutParams) SetTimeout ¶

func (o *FindConfigLogToStdoutParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config log to stdout params

func (*FindConfigLogToStdoutParams) WithContext ¶

WithContext adds the context to the find config log to stdout params

func (*FindConfigLogToStdoutParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config log to stdout params

func (*FindConfigLogToStdoutParams) WithTimeout ¶

WithTimeout adds the timeout to the find config log to stdout params

func (*FindConfigLogToStdoutParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigLogToStdoutReader ¶

type FindConfigLogToStdoutReader struct {
	// contains filtered or unexported fields
}

FindConfigLogToStdoutReader is a Reader for the FindConfigLogToStdout structure.

func (*FindConfigLogToStdoutReader) ReadResponse ¶

func (o *FindConfigLogToStdoutReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigLogToSyslogDefault ¶

type FindConfigLogToSyslogDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigLogToSyslogDefault handles this case with default header values.

unexpected error

func NewFindConfigLogToSyslogDefault ¶

func NewFindConfigLogToSyslogDefault(code int) *FindConfigLogToSyslogDefault

NewFindConfigLogToSyslogDefault creates a FindConfigLogToSyslogDefault with default headers values

func (*FindConfigLogToSyslogDefault) Code ¶

Code gets the status code for the find config log to syslog default response

func (*FindConfigLogToSyslogDefault) Error ¶

func (*FindConfigLogToSyslogDefault) GetPayload ¶

type FindConfigLogToSyslogOK ¶

type FindConfigLogToSyslogOK struct {
	Payload bool
}

FindConfigLogToSyslogOK handles this case with default header values.

Config value

func NewFindConfigLogToSyslogOK ¶

func NewFindConfigLogToSyslogOK() *FindConfigLogToSyslogOK

NewFindConfigLogToSyslogOK creates a FindConfigLogToSyslogOK with default headers values

func (*FindConfigLogToSyslogOK) GetPayload ¶

func (o *FindConfigLogToSyslogOK) GetPayload() bool

type FindConfigLogToSyslogParams ¶

type FindConfigLogToSyslogParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigLogToSyslogParams contains all the parameters to send to the API endpoint for the find config log to syslog operation typically these are written to a http.Request

func NewFindConfigLogToSyslogParams ¶

func NewFindConfigLogToSyslogParams() *FindConfigLogToSyslogParams

NewFindConfigLogToSyslogParams creates a new FindConfigLogToSyslogParams object with the default values initialized.

func NewFindConfigLogToSyslogParamsWithContext ¶

func NewFindConfigLogToSyslogParamsWithContext(ctx context.Context) *FindConfigLogToSyslogParams

NewFindConfigLogToSyslogParamsWithContext creates a new FindConfigLogToSyslogParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigLogToSyslogParamsWithHTTPClient ¶

func NewFindConfigLogToSyslogParamsWithHTTPClient(client *http.Client) *FindConfigLogToSyslogParams

NewFindConfigLogToSyslogParamsWithHTTPClient creates a new FindConfigLogToSyslogParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigLogToSyslogParamsWithTimeout ¶

func NewFindConfigLogToSyslogParamsWithTimeout(timeout time.Duration) *FindConfigLogToSyslogParams

NewFindConfigLogToSyslogParamsWithTimeout creates a new FindConfigLogToSyslogParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigLogToSyslogParams) SetContext ¶

func (o *FindConfigLogToSyslogParams) SetContext(ctx context.Context)

SetContext adds the context to the find config log to syslog params

func (*FindConfigLogToSyslogParams) SetHTTPClient ¶

func (o *FindConfigLogToSyslogParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config log to syslog params

func (*FindConfigLogToSyslogParams) SetTimeout ¶

func (o *FindConfigLogToSyslogParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config log to syslog params

func (*FindConfigLogToSyslogParams) WithContext ¶

WithContext adds the context to the find config log to syslog params

func (*FindConfigLogToSyslogParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config log to syslog params

func (*FindConfigLogToSyslogParams) WithTimeout ¶

WithTimeout adds the timeout to the find config log to syslog params

func (*FindConfigLogToSyslogParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigLogToSyslogReader ¶

type FindConfigLogToSyslogReader struct {
	// contains filtered or unexported fields
}

FindConfigLogToSyslogReader is a Reader for the FindConfigLogToSyslog structure.

func (*FindConfigLogToSyslogReader) ReadResponse ¶

func (o *FindConfigLogToSyslogReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigLoggerLogLevelDefault ¶

type FindConfigLoggerLogLevelDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigLoggerLogLevelDefault handles this case with default header values.

unexpected error

func NewFindConfigLoggerLogLevelDefault ¶

func NewFindConfigLoggerLogLevelDefault(code int) *FindConfigLoggerLogLevelDefault

NewFindConfigLoggerLogLevelDefault creates a FindConfigLoggerLogLevelDefault with default headers values

func (*FindConfigLoggerLogLevelDefault) Code ¶

Code gets the status code for the find config logger log level default response

func (*FindConfigLoggerLogLevelDefault) Error ¶

func (*FindConfigLoggerLogLevelDefault) GetPayload ¶

type FindConfigLoggerLogLevelOK ¶

type FindConfigLoggerLogLevelOK struct {
	Payload []string
}

FindConfigLoggerLogLevelOK handles this case with default header values.

Config value

func NewFindConfigLoggerLogLevelOK ¶

func NewFindConfigLoggerLogLevelOK() *FindConfigLoggerLogLevelOK

NewFindConfigLoggerLogLevelOK creates a FindConfigLoggerLogLevelOK with default headers values

func (*FindConfigLoggerLogLevelOK) GetPayload ¶

func (o *FindConfigLoggerLogLevelOK) GetPayload() []string

type FindConfigLoggerLogLevelParams ¶

type FindConfigLoggerLogLevelParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigLoggerLogLevelParams contains all the parameters to send to the API endpoint for the find config logger log level operation typically these are written to a http.Request

func NewFindConfigLoggerLogLevelParams ¶

func NewFindConfigLoggerLogLevelParams() *FindConfigLoggerLogLevelParams

NewFindConfigLoggerLogLevelParams creates a new FindConfigLoggerLogLevelParams object with the default values initialized.

func NewFindConfigLoggerLogLevelParamsWithContext ¶

func NewFindConfigLoggerLogLevelParamsWithContext(ctx context.Context) *FindConfigLoggerLogLevelParams

NewFindConfigLoggerLogLevelParamsWithContext creates a new FindConfigLoggerLogLevelParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigLoggerLogLevelParamsWithHTTPClient ¶

func NewFindConfigLoggerLogLevelParamsWithHTTPClient(client *http.Client) *FindConfigLoggerLogLevelParams

NewFindConfigLoggerLogLevelParamsWithHTTPClient creates a new FindConfigLoggerLogLevelParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigLoggerLogLevelParamsWithTimeout ¶

func NewFindConfigLoggerLogLevelParamsWithTimeout(timeout time.Duration) *FindConfigLoggerLogLevelParams

NewFindConfigLoggerLogLevelParamsWithTimeout creates a new FindConfigLoggerLogLevelParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigLoggerLogLevelParams) SetContext ¶

func (o *FindConfigLoggerLogLevelParams) SetContext(ctx context.Context)

SetContext adds the context to the find config logger log level params

func (*FindConfigLoggerLogLevelParams) SetHTTPClient ¶

func (o *FindConfigLoggerLogLevelParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config logger log level params

func (*FindConfigLoggerLogLevelParams) SetTimeout ¶

func (o *FindConfigLoggerLogLevelParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config logger log level params

func (*FindConfigLoggerLogLevelParams) WithContext ¶

WithContext adds the context to the find config logger log level params

func (*FindConfigLoggerLogLevelParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config logger log level params

func (*FindConfigLoggerLogLevelParams) WithTimeout ¶

WithTimeout adds the timeout to the find config logger log level params

func (*FindConfigLoggerLogLevelParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigLoggerLogLevelReader ¶

type FindConfigLoggerLogLevelReader struct {
	// contains filtered or unexported fields
}

FindConfigLoggerLogLevelReader is a Reader for the FindConfigLoggerLogLevel structure.

func (*FindConfigLoggerLogLevelReader) ReadResponse ¶

func (o *FindConfigLoggerLogLevelReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigLsaReclamationStepDefault ¶

type FindConfigLsaReclamationStepDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigLsaReclamationStepDefault handles this case with default header values.

unexpected error

func NewFindConfigLsaReclamationStepDefault ¶

func NewFindConfigLsaReclamationStepDefault(code int) *FindConfigLsaReclamationStepDefault

NewFindConfigLsaReclamationStepDefault creates a FindConfigLsaReclamationStepDefault with default headers values

func (*FindConfigLsaReclamationStepDefault) Code ¶

Code gets the status code for the find config lsa reclamation step default response

func (*FindConfigLsaReclamationStepDefault) Error ¶

func (*FindConfigLsaReclamationStepDefault) GetPayload ¶

type FindConfigLsaReclamationStepOK ¶

type FindConfigLsaReclamationStepOK struct {
	Payload int64
}

FindConfigLsaReclamationStepOK handles this case with default header values.

Config value

func NewFindConfigLsaReclamationStepOK ¶

func NewFindConfigLsaReclamationStepOK() *FindConfigLsaReclamationStepOK

NewFindConfigLsaReclamationStepOK creates a FindConfigLsaReclamationStepOK with default headers values

func (*FindConfigLsaReclamationStepOK) GetPayload ¶

func (o *FindConfigLsaReclamationStepOK) GetPayload() int64

type FindConfigLsaReclamationStepParams ¶

type FindConfigLsaReclamationStepParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigLsaReclamationStepParams contains all the parameters to send to the API endpoint for the find config lsa reclamation step operation typically these are written to a http.Request

func NewFindConfigLsaReclamationStepParams ¶

func NewFindConfigLsaReclamationStepParams() *FindConfigLsaReclamationStepParams

NewFindConfigLsaReclamationStepParams creates a new FindConfigLsaReclamationStepParams object with the default values initialized.

func NewFindConfigLsaReclamationStepParamsWithContext ¶

func NewFindConfigLsaReclamationStepParamsWithContext(ctx context.Context) *FindConfigLsaReclamationStepParams

NewFindConfigLsaReclamationStepParamsWithContext creates a new FindConfigLsaReclamationStepParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigLsaReclamationStepParamsWithHTTPClient ¶

func NewFindConfigLsaReclamationStepParamsWithHTTPClient(client *http.Client) *FindConfigLsaReclamationStepParams

NewFindConfigLsaReclamationStepParamsWithHTTPClient creates a new FindConfigLsaReclamationStepParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigLsaReclamationStepParamsWithTimeout ¶

func NewFindConfigLsaReclamationStepParamsWithTimeout(timeout time.Duration) *FindConfigLsaReclamationStepParams

NewFindConfigLsaReclamationStepParamsWithTimeout creates a new FindConfigLsaReclamationStepParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigLsaReclamationStepParams) SetContext ¶

SetContext adds the context to the find config lsa reclamation step params

func (*FindConfigLsaReclamationStepParams) SetHTTPClient ¶

func (o *FindConfigLsaReclamationStepParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config lsa reclamation step params

func (*FindConfigLsaReclamationStepParams) SetTimeout ¶

func (o *FindConfigLsaReclamationStepParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config lsa reclamation step params

func (*FindConfigLsaReclamationStepParams) WithContext ¶

WithContext adds the context to the find config lsa reclamation step params

func (*FindConfigLsaReclamationStepParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config lsa reclamation step params

func (*FindConfigLsaReclamationStepParams) WithTimeout ¶

WithTimeout adds the timeout to the find config lsa reclamation step params

func (*FindConfigLsaReclamationStepParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigLsaReclamationStepReader ¶

type FindConfigLsaReclamationStepReader struct {
	// contains filtered or unexported fields
}

FindConfigLsaReclamationStepReader is a Reader for the FindConfigLsaReclamationStep structure.

func (*FindConfigLsaReclamationStepReader) ReadResponse ¶

func (o *FindConfigLsaReclamationStepReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMaxHintWindowInMsDefault ¶

type FindConfigMaxHintWindowInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMaxHintWindowInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigMaxHintWindowInMsDefault ¶

func NewFindConfigMaxHintWindowInMsDefault(code int) *FindConfigMaxHintWindowInMsDefault

NewFindConfigMaxHintWindowInMsDefault creates a FindConfigMaxHintWindowInMsDefault with default headers values

func (*FindConfigMaxHintWindowInMsDefault) Code ¶

Code gets the status code for the find config max hint window in ms default response

func (*FindConfigMaxHintWindowInMsDefault) Error ¶

func (*FindConfigMaxHintWindowInMsDefault) GetPayload ¶

type FindConfigMaxHintWindowInMsOK ¶

type FindConfigMaxHintWindowInMsOK struct {
	Payload int64
}

FindConfigMaxHintWindowInMsOK handles this case with default header values.

Config value

func NewFindConfigMaxHintWindowInMsOK ¶

func NewFindConfigMaxHintWindowInMsOK() *FindConfigMaxHintWindowInMsOK

NewFindConfigMaxHintWindowInMsOK creates a FindConfigMaxHintWindowInMsOK with default headers values

func (*FindConfigMaxHintWindowInMsOK) GetPayload ¶

func (o *FindConfigMaxHintWindowInMsOK) GetPayload() int64

type FindConfigMaxHintWindowInMsParams ¶

type FindConfigMaxHintWindowInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMaxHintWindowInMsParams contains all the parameters to send to the API endpoint for the find config max hint window in ms operation typically these are written to a http.Request

func NewFindConfigMaxHintWindowInMsParams ¶

func NewFindConfigMaxHintWindowInMsParams() *FindConfigMaxHintWindowInMsParams

NewFindConfigMaxHintWindowInMsParams creates a new FindConfigMaxHintWindowInMsParams object with the default values initialized.

func NewFindConfigMaxHintWindowInMsParamsWithContext ¶

func NewFindConfigMaxHintWindowInMsParamsWithContext(ctx context.Context) *FindConfigMaxHintWindowInMsParams

NewFindConfigMaxHintWindowInMsParamsWithContext creates a new FindConfigMaxHintWindowInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMaxHintWindowInMsParamsWithHTTPClient ¶

func NewFindConfigMaxHintWindowInMsParamsWithHTTPClient(client *http.Client) *FindConfigMaxHintWindowInMsParams

NewFindConfigMaxHintWindowInMsParamsWithHTTPClient creates a new FindConfigMaxHintWindowInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMaxHintWindowInMsParamsWithTimeout ¶

func NewFindConfigMaxHintWindowInMsParamsWithTimeout(timeout time.Duration) *FindConfigMaxHintWindowInMsParams

NewFindConfigMaxHintWindowInMsParamsWithTimeout creates a new FindConfigMaxHintWindowInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMaxHintWindowInMsParams) SetContext ¶

SetContext adds the context to the find config max hint window in ms params

func (*FindConfigMaxHintWindowInMsParams) SetHTTPClient ¶

func (o *FindConfigMaxHintWindowInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config max hint window in ms params

func (*FindConfigMaxHintWindowInMsParams) SetTimeout ¶

func (o *FindConfigMaxHintWindowInMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config max hint window in ms params

func (*FindConfigMaxHintWindowInMsParams) WithContext ¶

WithContext adds the context to the find config max hint window in ms params

func (*FindConfigMaxHintWindowInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config max hint window in ms params

func (*FindConfigMaxHintWindowInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config max hint window in ms params

func (*FindConfigMaxHintWindowInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMaxHintWindowInMsReader ¶

type FindConfigMaxHintWindowInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigMaxHintWindowInMsReader is a Reader for the FindConfigMaxHintWindowInMs structure.

func (*FindConfigMaxHintWindowInMsReader) ReadResponse ¶

func (o *FindConfigMaxHintWindowInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMaxHintsDeliveryThreadsDefault ¶

type FindConfigMaxHintsDeliveryThreadsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMaxHintsDeliveryThreadsDefault handles this case with default header values.

unexpected error

func NewFindConfigMaxHintsDeliveryThreadsDefault ¶

func NewFindConfigMaxHintsDeliveryThreadsDefault(code int) *FindConfigMaxHintsDeliveryThreadsDefault

NewFindConfigMaxHintsDeliveryThreadsDefault creates a FindConfigMaxHintsDeliveryThreadsDefault with default headers values

func (*FindConfigMaxHintsDeliveryThreadsDefault) Code ¶

Code gets the status code for the find config max hints delivery threads default response

func (*FindConfigMaxHintsDeliveryThreadsDefault) Error ¶

func (*FindConfigMaxHintsDeliveryThreadsDefault) GetPayload ¶

type FindConfigMaxHintsDeliveryThreadsOK ¶

type FindConfigMaxHintsDeliveryThreadsOK struct {
	Payload int64
}

FindConfigMaxHintsDeliveryThreadsOK handles this case with default header values.

Config value

func NewFindConfigMaxHintsDeliveryThreadsOK ¶

func NewFindConfigMaxHintsDeliveryThreadsOK() *FindConfigMaxHintsDeliveryThreadsOK

NewFindConfigMaxHintsDeliveryThreadsOK creates a FindConfigMaxHintsDeliveryThreadsOK with default headers values

func (*FindConfigMaxHintsDeliveryThreadsOK) GetPayload ¶

type FindConfigMaxHintsDeliveryThreadsParams ¶

type FindConfigMaxHintsDeliveryThreadsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMaxHintsDeliveryThreadsParams contains all the parameters to send to the API endpoint for the find config max hints delivery threads operation typically these are written to a http.Request

func NewFindConfigMaxHintsDeliveryThreadsParams ¶

func NewFindConfigMaxHintsDeliveryThreadsParams() *FindConfigMaxHintsDeliveryThreadsParams

NewFindConfigMaxHintsDeliveryThreadsParams creates a new FindConfigMaxHintsDeliveryThreadsParams object with the default values initialized.

func NewFindConfigMaxHintsDeliveryThreadsParamsWithContext ¶

func NewFindConfigMaxHintsDeliveryThreadsParamsWithContext(ctx context.Context) *FindConfigMaxHintsDeliveryThreadsParams

NewFindConfigMaxHintsDeliveryThreadsParamsWithContext creates a new FindConfigMaxHintsDeliveryThreadsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMaxHintsDeliveryThreadsParamsWithHTTPClient ¶

func NewFindConfigMaxHintsDeliveryThreadsParamsWithHTTPClient(client *http.Client) *FindConfigMaxHintsDeliveryThreadsParams

NewFindConfigMaxHintsDeliveryThreadsParamsWithHTTPClient creates a new FindConfigMaxHintsDeliveryThreadsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMaxHintsDeliveryThreadsParamsWithTimeout ¶

func NewFindConfigMaxHintsDeliveryThreadsParamsWithTimeout(timeout time.Duration) *FindConfigMaxHintsDeliveryThreadsParams

NewFindConfigMaxHintsDeliveryThreadsParamsWithTimeout creates a new FindConfigMaxHintsDeliveryThreadsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMaxHintsDeliveryThreadsParams) SetContext ¶

SetContext adds the context to the find config max hints delivery threads params

func (*FindConfigMaxHintsDeliveryThreadsParams) SetHTTPClient ¶

func (o *FindConfigMaxHintsDeliveryThreadsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config max hints delivery threads params

func (*FindConfigMaxHintsDeliveryThreadsParams) SetTimeout ¶

func (o *FindConfigMaxHintsDeliveryThreadsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config max hints delivery threads params

func (*FindConfigMaxHintsDeliveryThreadsParams) WithContext ¶

WithContext adds the context to the find config max hints delivery threads params

func (*FindConfigMaxHintsDeliveryThreadsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config max hints delivery threads params

func (*FindConfigMaxHintsDeliveryThreadsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config max hints delivery threads params

func (*FindConfigMaxHintsDeliveryThreadsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMaxHintsDeliveryThreadsReader ¶

type FindConfigMaxHintsDeliveryThreadsReader struct {
	// contains filtered or unexported fields
}

FindConfigMaxHintsDeliveryThreadsReader is a Reader for the FindConfigMaxHintsDeliveryThreads structure.

func (*FindConfigMaxHintsDeliveryThreadsReader) ReadResponse ¶

func (o *FindConfigMaxHintsDeliveryThreadsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemoryAllocatorDefault ¶

type FindConfigMemoryAllocatorDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemoryAllocatorDefault handles this case with default header values.

unexpected error

func NewFindConfigMemoryAllocatorDefault ¶

func NewFindConfigMemoryAllocatorDefault(code int) *FindConfigMemoryAllocatorDefault

NewFindConfigMemoryAllocatorDefault creates a FindConfigMemoryAllocatorDefault with default headers values

func (*FindConfigMemoryAllocatorDefault) Code ¶

Code gets the status code for the find config memory allocator default response

func (*FindConfigMemoryAllocatorDefault) Error ¶

func (*FindConfigMemoryAllocatorDefault) GetPayload ¶

type FindConfigMemoryAllocatorOK ¶

type FindConfigMemoryAllocatorOK struct {
	Payload string
}

FindConfigMemoryAllocatorOK handles this case with default header values.

Config value

func NewFindConfigMemoryAllocatorOK ¶

func NewFindConfigMemoryAllocatorOK() *FindConfigMemoryAllocatorOK

NewFindConfigMemoryAllocatorOK creates a FindConfigMemoryAllocatorOK with default headers values

func (*FindConfigMemoryAllocatorOK) GetPayload ¶

func (o *FindConfigMemoryAllocatorOK) GetPayload() string

type FindConfigMemoryAllocatorParams ¶

type FindConfigMemoryAllocatorParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemoryAllocatorParams contains all the parameters to send to the API endpoint for the find config memory allocator operation typically these are written to a http.Request

func NewFindConfigMemoryAllocatorParams ¶

func NewFindConfigMemoryAllocatorParams() *FindConfigMemoryAllocatorParams

NewFindConfigMemoryAllocatorParams creates a new FindConfigMemoryAllocatorParams object with the default values initialized.

func NewFindConfigMemoryAllocatorParamsWithContext ¶

func NewFindConfigMemoryAllocatorParamsWithContext(ctx context.Context) *FindConfigMemoryAllocatorParams

NewFindConfigMemoryAllocatorParamsWithContext creates a new FindConfigMemoryAllocatorParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemoryAllocatorParamsWithHTTPClient ¶

func NewFindConfigMemoryAllocatorParamsWithHTTPClient(client *http.Client) *FindConfigMemoryAllocatorParams

NewFindConfigMemoryAllocatorParamsWithHTTPClient creates a new FindConfigMemoryAllocatorParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemoryAllocatorParamsWithTimeout ¶

func NewFindConfigMemoryAllocatorParamsWithTimeout(timeout time.Duration) *FindConfigMemoryAllocatorParams

NewFindConfigMemoryAllocatorParamsWithTimeout creates a new FindConfigMemoryAllocatorParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemoryAllocatorParams) SetContext ¶

func (o *FindConfigMemoryAllocatorParams) SetContext(ctx context.Context)

SetContext adds the context to the find config memory allocator params

func (*FindConfigMemoryAllocatorParams) SetHTTPClient ¶

func (o *FindConfigMemoryAllocatorParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memory allocator params

func (*FindConfigMemoryAllocatorParams) SetTimeout ¶

func (o *FindConfigMemoryAllocatorParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config memory allocator params

func (*FindConfigMemoryAllocatorParams) WithContext ¶

WithContext adds the context to the find config memory allocator params

func (*FindConfigMemoryAllocatorParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memory allocator params

func (*FindConfigMemoryAllocatorParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memory allocator params

func (*FindConfigMemoryAllocatorParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemoryAllocatorReader ¶

type FindConfigMemoryAllocatorReader struct {
	// contains filtered or unexported fields
}

FindConfigMemoryAllocatorReader is a Reader for the FindConfigMemoryAllocator structure.

func (*FindConfigMemoryAllocatorReader) ReadResponse ¶

func (o *FindConfigMemoryAllocatorReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemtableAllocationTypeDefault ¶

type FindConfigMemtableAllocationTypeDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemtableAllocationTypeDefault handles this case with default header values.

unexpected error

func NewFindConfigMemtableAllocationTypeDefault ¶

func NewFindConfigMemtableAllocationTypeDefault(code int) *FindConfigMemtableAllocationTypeDefault

NewFindConfigMemtableAllocationTypeDefault creates a FindConfigMemtableAllocationTypeDefault with default headers values

func (*FindConfigMemtableAllocationTypeDefault) Code ¶

Code gets the status code for the find config memtable allocation type default response

func (*FindConfigMemtableAllocationTypeDefault) Error ¶

func (*FindConfigMemtableAllocationTypeDefault) GetPayload ¶

type FindConfigMemtableAllocationTypeOK ¶

type FindConfigMemtableAllocationTypeOK struct {
	Payload string
}

FindConfigMemtableAllocationTypeOK handles this case with default header values.

Config value

func NewFindConfigMemtableAllocationTypeOK ¶

func NewFindConfigMemtableAllocationTypeOK() *FindConfigMemtableAllocationTypeOK

NewFindConfigMemtableAllocationTypeOK creates a FindConfigMemtableAllocationTypeOK with default headers values

func (*FindConfigMemtableAllocationTypeOK) GetPayload ¶

type FindConfigMemtableAllocationTypeParams ¶

type FindConfigMemtableAllocationTypeParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemtableAllocationTypeParams contains all the parameters to send to the API endpoint for the find config memtable allocation type operation typically these are written to a http.Request

func NewFindConfigMemtableAllocationTypeParams ¶

func NewFindConfigMemtableAllocationTypeParams() *FindConfigMemtableAllocationTypeParams

NewFindConfigMemtableAllocationTypeParams creates a new FindConfigMemtableAllocationTypeParams object with the default values initialized.

func NewFindConfigMemtableAllocationTypeParamsWithContext ¶

func NewFindConfigMemtableAllocationTypeParamsWithContext(ctx context.Context) *FindConfigMemtableAllocationTypeParams

NewFindConfigMemtableAllocationTypeParamsWithContext creates a new FindConfigMemtableAllocationTypeParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemtableAllocationTypeParamsWithHTTPClient ¶

func NewFindConfigMemtableAllocationTypeParamsWithHTTPClient(client *http.Client) *FindConfigMemtableAllocationTypeParams

NewFindConfigMemtableAllocationTypeParamsWithHTTPClient creates a new FindConfigMemtableAllocationTypeParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemtableAllocationTypeParamsWithTimeout ¶

func NewFindConfigMemtableAllocationTypeParamsWithTimeout(timeout time.Duration) *FindConfigMemtableAllocationTypeParams

NewFindConfigMemtableAllocationTypeParamsWithTimeout creates a new FindConfigMemtableAllocationTypeParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemtableAllocationTypeParams) SetContext ¶

SetContext adds the context to the find config memtable allocation type params

func (*FindConfigMemtableAllocationTypeParams) SetHTTPClient ¶

func (o *FindConfigMemtableAllocationTypeParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memtable allocation type params

func (*FindConfigMemtableAllocationTypeParams) SetTimeout ¶

func (o *FindConfigMemtableAllocationTypeParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config memtable allocation type params

func (*FindConfigMemtableAllocationTypeParams) WithContext ¶

WithContext adds the context to the find config memtable allocation type params

func (*FindConfigMemtableAllocationTypeParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memtable allocation type params

func (*FindConfigMemtableAllocationTypeParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memtable allocation type params

func (*FindConfigMemtableAllocationTypeParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemtableAllocationTypeReader ¶

type FindConfigMemtableAllocationTypeReader struct {
	// contains filtered or unexported fields
}

FindConfigMemtableAllocationTypeReader is a Reader for the FindConfigMemtableAllocationType structure.

func (*FindConfigMemtableAllocationTypeReader) ReadResponse ¶

func (o *FindConfigMemtableAllocationTypeReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemtableCleanupThresholdDefault ¶

type FindConfigMemtableCleanupThresholdDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemtableCleanupThresholdDefault handles this case with default header values.

unexpected error

func NewFindConfigMemtableCleanupThresholdDefault ¶

func NewFindConfigMemtableCleanupThresholdDefault(code int) *FindConfigMemtableCleanupThresholdDefault

NewFindConfigMemtableCleanupThresholdDefault creates a FindConfigMemtableCleanupThresholdDefault with default headers values

func (*FindConfigMemtableCleanupThresholdDefault) Code ¶

Code gets the status code for the find config memtable cleanup threshold default response

func (*FindConfigMemtableCleanupThresholdDefault) Error ¶

func (*FindConfigMemtableCleanupThresholdDefault) GetPayload ¶

type FindConfigMemtableCleanupThresholdOK ¶

type FindConfigMemtableCleanupThresholdOK struct {
	Payload float64
}

FindConfigMemtableCleanupThresholdOK handles this case with default header values.

Config value

func NewFindConfigMemtableCleanupThresholdOK ¶

func NewFindConfigMemtableCleanupThresholdOK() *FindConfigMemtableCleanupThresholdOK

NewFindConfigMemtableCleanupThresholdOK creates a FindConfigMemtableCleanupThresholdOK with default headers values

func (*FindConfigMemtableCleanupThresholdOK) GetPayload ¶

type FindConfigMemtableCleanupThresholdParams ¶

type FindConfigMemtableCleanupThresholdParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemtableCleanupThresholdParams contains all the parameters to send to the API endpoint for the find config memtable cleanup threshold operation typically these are written to a http.Request

func NewFindConfigMemtableCleanupThresholdParams ¶

func NewFindConfigMemtableCleanupThresholdParams() *FindConfigMemtableCleanupThresholdParams

NewFindConfigMemtableCleanupThresholdParams creates a new FindConfigMemtableCleanupThresholdParams object with the default values initialized.

func NewFindConfigMemtableCleanupThresholdParamsWithContext ¶

func NewFindConfigMemtableCleanupThresholdParamsWithContext(ctx context.Context) *FindConfigMemtableCleanupThresholdParams

NewFindConfigMemtableCleanupThresholdParamsWithContext creates a new FindConfigMemtableCleanupThresholdParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemtableCleanupThresholdParamsWithHTTPClient ¶

func NewFindConfigMemtableCleanupThresholdParamsWithHTTPClient(client *http.Client) *FindConfigMemtableCleanupThresholdParams

NewFindConfigMemtableCleanupThresholdParamsWithHTTPClient creates a new FindConfigMemtableCleanupThresholdParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemtableCleanupThresholdParamsWithTimeout ¶

func NewFindConfigMemtableCleanupThresholdParamsWithTimeout(timeout time.Duration) *FindConfigMemtableCleanupThresholdParams

NewFindConfigMemtableCleanupThresholdParamsWithTimeout creates a new FindConfigMemtableCleanupThresholdParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemtableCleanupThresholdParams) SetContext ¶

SetContext adds the context to the find config memtable cleanup threshold params

func (*FindConfigMemtableCleanupThresholdParams) SetHTTPClient ¶

func (o *FindConfigMemtableCleanupThresholdParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memtable cleanup threshold params

func (*FindConfigMemtableCleanupThresholdParams) SetTimeout ¶

SetTimeout adds the timeout to the find config memtable cleanup threshold params

func (*FindConfigMemtableCleanupThresholdParams) WithContext ¶

WithContext adds the context to the find config memtable cleanup threshold params

func (*FindConfigMemtableCleanupThresholdParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memtable cleanup threshold params

func (*FindConfigMemtableCleanupThresholdParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memtable cleanup threshold params

func (*FindConfigMemtableCleanupThresholdParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemtableCleanupThresholdReader ¶

type FindConfigMemtableCleanupThresholdReader struct {
	// contains filtered or unexported fields
}

FindConfigMemtableCleanupThresholdReader is a Reader for the FindConfigMemtableCleanupThreshold structure.

func (*FindConfigMemtableCleanupThresholdReader) ReadResponse ¶

func (o *FindConfigMemtableCleanupThresholdReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemtableFlushQueueSizeDefault ¶

type FindConfigMemtableFlushQueueSizeDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemtableFlushQueueSizeDefault handles this case with default header values.

unexpected error

func NewFindConfigMemtableFlushQueueSizeDefault ¶

func NewFindConfigMemtableFlushQueueSizeDefault(code int) *FindConfigMemtableFlushQueueSizeDefault

NewFindConfigMemtableFlushQueueSizeDefault creates a FindConfigMemtableFlushQueueSizeDefault with default headers values

func (*FindConfigMemtableFlushQueueSizeDefault) Code ¶

Code gets the status code for the find config memtable flush queue size default response

func (*FindConfigMemtableFlushQueueSizeDefault) Error ¶

func (*FindConfigMemtableFlushQueueSizeDefault) GetPayload ¶

type FindConfigMemtableFlushQueueSizeOK ¶

type FindConfigMemtableFlushQueueSizeOK struct {
	Payload int64
}

FindConfigMemtableFlushQueueSizeOK handles this case with default header values.

Config value

func NewFindConfigMemtableFlushQueueSizeOK ¶

func NewFindConfigMemtableFlushQueueSizeOK() *FindConfigMemtableFlushQueueSizeOK

NewFindConfigMemtableFlushQueueSizeOK creates a FindConfigMemtableFlushQueueSizeOK with default headers values

func (*FindConfigMemtableFlushQueueSizeOK) GetPayload ¶

func (o *FindConfigMemtableFlushQueueSizeOK) GetPayload() int64

type FindConfigMemtableFlushQueueSizeParams ¶

type FindConfigMemtableFlushQueueSizeParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemtableFlushQueueSizeParams contains all the parameters to send to the API endpoint for the find config memtable flush queue size operation typically these are written to a http.Request

func NewFindConfigMemtableFlushQueueSizeParams ¶

func NewFindConfigMemtableFlushQueueSizeParams() *FindConfigMemtableFlushQueueSizeParams

NewFindConfigMemtableFlushQueueSizeParams creates a new FindConfigMemtableFlushQueueSizeParams object with the default values initialized.

func NewFindConfigMemtableFlushQueueSizeParamsWithContext ¶

func NewFindConfigMemtableFlushQueueSizeParamsWithContext(ctx context.Context) *FindConfigMemtableFlushQueueSizeParams

NewFindConfigMemtableFlushQueueSizeParamsWithContext creates a new FindConfigMemtableFlushQueueSizeParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemtableFlushQueueSizeParamsWithHTTPClient ¶

func NewFindConfigMemtableFlushQueueSizeParamsWithHTTPClient(client *http.Client) *FindConfigMemtableFlushQueueSizeParams

NewFindConfigMemtableFlushQueueSizeParamsWithHTTPClient creates a new FindConfigMemtableFlushQueueSizeParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemtableFlushQueueSizeParamsWithTimeout ¶

func NewFindConfigMemtableFlushQueueSizeParamsWithTimeout(timeout time.Duration) *FindConfigMemtableFlushQueueSizeParams

NewFindConfigMemtableFlushQueueSizeParamsWithTimeout creates a new FindConfigMemtableFlushQueueSizeParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemtableFlushQueueSizeParams) SetContext ¶

SetContext adds the context to the find config memtable flush queue size params

func (*FindConfigMemtableFlushQueueSizeParams) SetHTTPClient ¶

func (o *FindConfigMemtableFlushQueueSizeParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memtable flush queue size params

func (*FindConfigMemtableFlushQueueSizeParams) SetTimeout ¶

func (o *FindConfigMemtableFlushQueueSizeParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config memtable flush queue size params

func (*FindConfigMemtableFlushQueueSizeParams) WithContext ¶

WithContext adds the context to the find config memtable flush queue size params

func (*FindConfigMemtableFlushQueueSizeParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memtable flush queue size params

func (*FindConfigMemtableFlushQueueSizeParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memtable flush queue size params

func (*FindConfigMemtableFlushQueueSizeParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemtableFlushQueueSizeReader ¶

type FindConfigMemtableFlushQueueSizeReader struct {
	// contains filtered or unexported fields
}

FindConfigMemtableFlushQueueSizeReader is a Reader for the FindConfigMemtableFlushQueueSize structure.

func (*FindConfigMemtableFlushQueueSizeReader) ReadResponse ¶

func (o *FindConfigMemtableFlushQueueSizeReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemtableFlushStaticSharesDefault ¶

type FindConfigMemtableFlushStaticSharesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemtableFlushStaticSharesDefault handles this case with default header values.

unexpected error

func NewFindConfigMemtableFlushStaticSharesDefault ¶

func NewFindConfigMemtableFlushStaticSharesDefault(code int) *FindConfigMemtableFlushStaticSharesDefault

NewFindConfigMemtableFlushStaticSharesDefault creates a FindConfigMemtableFlushStaticSharesDefault with default headers values

func (*FindConfigMemtableFlushStaticSharesDefault) Code ¶

Code gets the status code for the find config memtable flush static shares default response

func (*FindConfigMemtableFlushStaticSharesDefault) Error ¶

func (*FindConfigMemtableFlushStaticSharesDefault) GetPayload ¶

type FindConfigMemtableFlushStaticSharesOK ¶

type FindConfigMemtableFlushStaticSharesOK struct {
	Payload float64
}

FindConfigMemtableFlushStaticSharesOK handles this case with default header values.

Config value

func NewFindConfigMemtableFlushStaticSharesOK ¶

func NewFindConfigMemtableFlushStaticSharesOK() *FindConfigMemtableFlushStaticSharesOK

NewFindConfigMemtableFlushStaticSharesOK creates a FindConfigMemtableFlushStaticSharesOK with default headers values

func (*FindConfigMemtableFlushStaticSharesOK) GetPayload ¶

type FindConfigMemtableFlushStaticSharesParams ¶

type FindConfigMemtableFlushStaticSharesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemtableFlushStaticSharesParams contains all the parameters to send to the API endpoint for the find config memtable flush static shares operation typically these are written to a http.Request

func NewFindConfigMemtableFlushStaticSharesParams ¶

func NewFindConfigMemtableFlushStaticSharesParams() *FindConfigMemtableFlushStaticSharesParams

NewFindConfigMemtableFlushStaticSharesParams creates a new FindConfigMemtableFlushStaticSharesParams object with the default values initialized.

func NewFindConfigMemtableFlushStaticSharesParamsWithContext ¶

func NewFindConfigMemtableFlushStaticSharesParamsWithContext(ctx context.Context) *FindConfigMemtableFlushStaticSharesParams

NewFindConfigMemtableFlushStaticSharesParamsWithContext creates a new FindConfigMemtableFlushStaticSharesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemtableFlushStaticSharesParamsWithHTTPClient ¶

func NewFindConfigMemtableFlushStaticSharesParamsWithHTTPClient(client *http.Client) *FindConfigMemtableFlushStaticSharesParams

NewFindConfigMemtableFlushStaticSharesParamsWithHTTPClient creates a new FindConfigMemtableFlushStaticSharesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemtableFlushStaticSharesParamsWithTimeout ¶

func NewFindConfigMemtableFlushStaticSharesParamsWithTimeout(timeout time.Duration) *FindConfigMemtableFlushStaticSharesParams

NewFindConfigMemtableFlushStaticSharesParamsWithTimeout creates a new FindConfigMemtableFlushStaticSharesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemtableFlushStaticSharesParams) SetContext ¶

SetContext adds the context to the find config memtable flush static shares params

func (*FindConfigMemtableFlushStaticSharesParams) SetHTTPClient ¶

func (o *FindConfigMemtableFlushStaticSharesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memtable flush static shares params

func (*FindConfigMemtableFlushStaticSharesParams) SetTimeout ¶

SetTimeout adds the timeout to the find config memtable flush static shares params

func (*FindConfigMemtableFlushStaticSharesParams) WithContext ¶

WithContext adds the context to the find config memtable flush static shares params

func (*FindConfigMemtableFlushStaticSharesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memtable flush static shares params

func (*FindConfigMemtableFlushStaticSharesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memtable flush static shares params

func (*FindConfigMemtableFlushStaticSharesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemtableFlushStaticSharesReader ¶

type FindConfigMemtableFlushStaticSharesReader struct {
	// contains filtered or unexported fields
}

FindConfigMemtableFlushStaticSharesReader is a Reader for the FindConfigMemtableFlushStaticShares structure.

func (*FindConfigMemtableFlushStaticSharesReader) ReadResponse ¶

func (o *FindConfigMemtableFlushStaticSharesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemtableFlushWritersDefault ¶

type FindConfigMemtableFlushWritersDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemtableFlushWritersDefault handles this case with default header values.

unexpected error

func NewFindConfigMemtableFlushWritersDefault ¶

func NewFindConfigMemtableFlushWritersDefault(code int) *FindConfigMemtableFlushWritersDefault

NewFindConfigMemtableFlushWritersDefault creates a FindConfigMemtableFlushWritersDefault with default headers values

func (*FindConfigMemtableFlushWritersDefault) Code ¶

Code gets the status code for the find config memtable flush writers default response

func (*FindConfigMemtableFlushWritersDefault) Error ¶

func (*FindConfigMemtableFlushWritersDefault) GetPayload ¶

type FindConfigMemtableFlushWritersOK ¶

type FindConfigMemtableFlushWritersOK struct {
	Payload int64
}

FindConfigMemtableFlushWritersOK handles this case with default header values.

Config value

func NewFindConfigMemtableFlushWritersOK ¶

func NewFindConfigMemtableFlushWritersOK() *FindConfigMemtableFlushWritersOK

NewFindConfigMemtableFlushWritersOK creates a FindConfigMemtableFlushWritersOK with default headers values

func (*FindConfigMemtableFlushWritersOK) GetPayload ¶

func (o *FindConfigMemtableFlushWritersOK) GetPayload() int64

type FindConfigMemtableFlushWritersParams ¶

type FindConfigMemtableFlushWritersParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemtableFlushWritersParams contains all the parameters to send to the API endpoint for the find config memtable flush writers operation typically these are written to a http.Request

func NewFindConfigMemtableFlushWritersParams ¶

func NewFindConfigMemtableFlushWritersParams() *FindConfigMemtableFlushWritersParams

NewFindConfigMemtableFlushWritersParams creates a new FindConfigMemtableFlushWritersParams object with the default values initialized.

func NewFindConfigMemtableFlushWritersParamsWithContext ¶

func NewFindConfigMemtableFlushWritersParamsWithContext(ctx context.Context) *FindConfigMemtableFlushWritersParams

NewFindConfigMemtableFlushWritersParamsWithContext creates a new FindConfigMemtableFlushWritersParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemtableFlushWritersParamsWithHTTPClient ¶

func NewFindConfigMemtableFlushWritersParamsWithHTTPClient(client *http.Client) *FindConfigMemtableFlushWritersParams

NewFindConfigMemtableFlushWritersParamsWithHTTPClient creates a new FindConfigMemtableFlushWritersParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemtableFlushWritersParamsWithTimeout ¶

func NewFindConfigMemtableFlushWritersParamsWithTimeout(timeout time.Duration) *FindConfigMemtableFlushWritersParams

NewFindConfigMemtableFlushWritersParamsWithTimeout creates a new FindConfigMemtableFlushWritersParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemtableFlushWritersParams) SetContext ¶

SetContext adds the context to the find config memtable flush writers params

func (*FindConfigMemtableFlushWritersParams) SetHTTPClient ¶

func (o *FindConfigMemtableFlushWritersParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memtable flush writers params

func (*FindConfigMemtableFlushWritersParams) SetTimeout ¶

func (o *FindConfigMemtableFlushWritersParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config memtable flush writers params

func (*FindConfigMemtableFlushWritersParams) WithContext ¶

WithContext adds the context to the find config memtable flush writers params

func (*FindConfigMemtableFlushWritersParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memtable flush writers params

func (*FindConfigMemtableFlushWritersParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memtable flush writers params

func (*FindConfigMemtableFlushWritersParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemtableFlushWritersReader ¶

type FindConfigMemtableFlushWritersReader struct {
	// contains filtered or unexported fields
}

FindConfigMemtableFlushWritersReader is a Reader for the FindConfigMemtableFlushWriters structure.

func (*FindConfigMemtableFlushWritersReader) ReadResponse ¶

func (o *FindConfigMemtableFlushWritersReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemtableHeapSpaceInMbDefault ¶

type FindConfigMemtableHeapSpaceInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemtableHeapSpaceInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigMemtableHeapSpaceInMbDefault ¶

func NewFindConfigMemtableHeapSpaceInMbDefault(code int) *FindConfigMemtableHeapSpaceInMbDefault

NewFindConfigMemtableHeapSpaceInMbDefault creates a FindConfigMemtableHeapSpaceInMbDefault with default headers values

func (*FindConfigMemtableHeapSpaceInMbDefault) Code ¶

Code gets the status code for the find config memtable heap space in mb default response

func (*FindConfigMemtableHeapSpaceInMbDefault) Error ¶

func (*FindConfigMemtableHeapSpaceInMbDefault) GetPayload ¶

type FindConfigMemtableHeapSpaceInMbOK ¶

type FindConfigMemtableHeapSpaceInMbOK struct {
	Payload int64
}

FindConfigMemtableHeapSpaceInMbOK handles this case with default header values.

Config value

func NewFindConfigMemtableHeapSpaceInMbOK ¶

func NewFindConfigMemtableHeapSpaceInMbOK() *FindConfigMemtableHeapSpaceInMbOK

NewFindConfigMemtableHeapSpaceInMbOK creates a FindConfigMemtableHeapSpaceInMbOK with default headers values

func (*FindConfigMemtableHeapSpaceInMbOK) GetPayload ¶

func (o *FindConfigMemtableHeapSpaceInMbOK) GetPayload() int64

type FindConfigMemtableHeapSpaceInMbParams ¶

type FindConfigMemtableHeapSpaceInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemtableHeapSpaceInMbParams contains all the parameters to send to the API endpoint for the find config memtable heap space in mb operation typically these are written to a http.Request

func NewFindConfigMemtableHeapSpaceInMbParams ¶

func NewFindConfigMemtableHeapSpaceInMbParams() *FindConfigMemtableHeapSpaceInMbParams

NewFindConfigMemtableHeapSpaceInMbParams creates a new FindConfigMemtableHeapSpaceInMbParams object with the default values initialized.

func NewFindConfigMemtableHeapSpaceInMbParamsWithContext ¶

func NewFindConfigMemtableHeapSpaceInMbParamsWithContext(ctx context.Context) *FindConfigMemtableHeapSpaceInMbParams

NewFindConfigMemtableHeapSpaceInMbParamsWithContext creates a new FindConfigMemtableHeapSpaceInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemtableHeapSpaceInMbParamsWithHTTPClient ¶

func NewFindConfigMemtableHeapSpaceInMbParamsWithHTTPClient(client *http.Client) *FindConfigMemtableHeapSpaceInMbParams

NewFindConfigMemtableHeapSpaceInMbParamsWithHTTPClient creates a new FindConfigMemtableHeapSpaceInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemtableHeapSpaceInMbParamsWithTimeout ¶

func NewFindConfigMemtableHeapSpaceInMbParamsWithTimeout(timeout time.Duration) *FindConfigMemtableHeapSpaceInMbParams

NewFindConfigMemtableHeapSpaceInMbParamsWithTimeout creates a new FindConfigMemtableHeapSpaceInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemtableHeapSpaceInMbParams) SetContext ¶

SetContext adds the context to the find config memtable heap space in mb params

func (*FindConfigMemtableHeapSpaceInMbParams) SetHTTPClient ¶

func (o *FindConfigMemtableHeapSpaceInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memtable heap space in mb params

func (*FindConfigMemtableHeapSpaceInMbParams) SetTimeout ¶

func (o *FindConfigMemtableHeapSpaceInMbParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config memtable heap space in mb params

func (*FindConfigMemtableHeapSpaceInMbParams) WithContext ¶

WithContext adds the context to the find config memtable heap space in mb params

func (*FindConfigMemtableHeapSpaceInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memtable heap space in mb params

func (*FindConfigMemtableHeapSpaceInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memtable heap space in mb params

func (*FindConfigMemtableHeapSpaceInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemtableHeapSpaceInMbReader ¶

type FindConfigMemtableHeapSpaceInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigMemtableHeapSpaceInMbReader is a Reader for the FindConfigMemtableHeapSpaceInMb structure.

func (*FindConfigMemtableHeapSpaceInMbReader) ReadResponse ¶

func (o *FindConfigMemtableHeapSpaceInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemtableOffheapSpaceInMbDefault ¶

type FindConfigMemtableOffheapSpaceInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemtableOffheapSpaceInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigMemtableOffheapSpaceInMbDefault ¶

func NewFindConfigMemtableOffheapSpaceInMbDefault(code int) *FindConfigMemtableOffheapSpaceInMbDefault

NewFindConfigMemtableOffheapSpaceInMbDefault creates a FindConfigMemtableOffheapSpaceInMbDefault with default headers values

func (*FindConfigMemtableOffheapSpaceInMbDefault) Code ¶

Code gets the status code for the find config memtable offheap space in mb default response

func (*FindConfigMemtableOffheapSpaceInMbDefault) Error ¶

func (*FindConfigMemtableOffheapSpaceInMbDefault) GetPayload ¶

type FindConfigMemtableOffheapSpaceInMbOK ¶

type FindConfigMemtableOffheapSpaceInMbOK struct {
	Payload int64
}

FindConfigMemtableOffheapSpaceInMbOK handles this case with default header values.

Config value

func NewFindConfigMemtableOffheapSpaceInMbOK ¶

func NewFindConfigMemtableOffheapSpaceInMbOK() *FindConfigMemtableOffheapSpaceInMbOK

NewFindConfigMemtableOffheapSpaceInMbOK creates a FindConfigMemtableOffheapSpaceInMbOK with default headers values

func (*FindConfigMemtableOffheapSpaceInMbOK) GetPayload ¶

type FindConfigMemtableOffheapSpaceInMbParams ¶

type FindConfigMemtableOffheapSpaceInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemtableOffheapSpaceInMbParams contains all the parameters to send to the API endpoint for the find config memtable offheap space in mb operation typically these are written to a http.Request

func NewFindConfigMemtableOffheapSpaceInMbParams ¶

func NewFindConfigMemtableOffheapSpaceInMbParams() *FindConfigMemtableOffheapSpaceInMbParams

NewFindConfigMemtableOffheapSpaceInMbParams creates a new FindConfigMemtableOffheapSpaceInMbParams object with the default values initialized.

func NewFindConfigMemtableOffheapSpaceInMbParamsWithContext ¶

func NewFindConfigMemtableOffheapSpaceInMbParamsWithContext(ctx context.Context) *FindConfigMemtableOffheapSpaceInMbParams

NewFindConfigMemtableOffheapSpaceInMbParamsWithContext creates a new FindConfigMemtableOffheapSpaceInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemtableOffheapSpaceInMbParamsWithHTTPClient ¶

func NewFindConfigMemtableOffheapSpaceInMbParamsWithHTTPClient(client *http.Client) *FindConfigMemtableOffheapSpaceInMbParams

NewFindConfigMemtableOffheapSpaceInMbParamsWithHTTPClient creates a new FindConfigMemtableOffheapSpaceInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemtableOffheapSpaceInMbParamsWithTimeout ¶

func NewFindConfigMemtableOffheapSpaceInMbParamsWithTimeout(timeout time.Duration) *FindConfigMemtableOffheapSpaceInMbParams

NewFindConfigMemtableOffheapSpaceInMbParamsWithTimeout creates a new FindConfigMemtableOffheapSpaceInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemtableOffheapSpaceInMbParams) SetContext ¶

SetContext adds the context to the find config memtable offheap space in mb params

func (*FindConfigMemtableOffheapSpaceInMbParams) SetHTTPClient ¶

func (o *FindConfigMemtableOffheapSpaceInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memtable offheap space in mb params

func (*FindConfigMemtableOffheapSpaceInMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config memtable offheap space in mb params

func (*FindConfigMemtableOffheapSpaceInMbParams) WithContext ¶

WithContext adds the context to the find config memtable offheap space in mb params

func (*FindConfigMemtableOffheapSpaceInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memtable offheap space in mb params

func (*FindConfigMemtableOffheapSpaceInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memtable offheap space in mb params

func (*FindConfigMemtableOffheapSpaceInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemtableOffheapSpaceInMbReader ¶

type FindConfigMemtableOffheapSpaceInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigMemtableOffheapSpaceInMbReader is a Reader for the FindConfigMemtableOffheapSpaceInMb structure.

func (*FindConfigMemtableOffheapSpaceInMbReader) ReadResponse ¶

func (o *FindConfigMemtableOffheapSpaceInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMemtableTotalSpaceInMbDefault ¶

type FindConfigMemtableTotalSpaceInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMemtableTotalSpaceInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigMemtableTotalSpaceInMbDefault ¶

func NewFindConfigMemtableTotalSpaceInMbDefault(code int) *FindConfigMemtableTotalSpaceInMbDefault

NewFindConfigMemtableTotalSpaceInMbDefault creates a FindConfigMemtableTotalSpaceInMbDefault with default headers values

func (*FindConfigMemtableTotalSpaceInMbDefault) Code ¶

Code gets the status code for the find config memtable total space in mb default response

func (*FindConfigMemtableTotalSpaceInMbDefault) Error ¶

func (*FindConfigMemtableTotalSpaceInMbDefault) GetPayload ¶

type FindConfigMemtableTotalSpaceInMbOK ¶

type FindConfigMemtableTotalSpaceInMbOK struct {
	Payload int64
}

FindConfigMemtableTotalSpaceInMbOK handles this case with default header values.

Config value

func NewFindConfigMemtableTotalSpaceInMbOK ¶

func NewFindConfigMemtableTotalSpaceInMbOK() *FindConfigMemtableTotalSpaceInMbOK

NewFindConfigMemtableTotalSpaceInMbOK creates a FindConfigMemtableTotalSpaceInMbOK with default headers values

func (*FindConfigMemtableTotalSpaceInMbOK) GetPayload ¶

func (o *FindConfigMemtableTotalSpaceInMbOK) GetPayload() int64

type FindConfigMemtableTotalSpaceInMbParams ¶

type FindConfigMemtableTotalSpaceInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMemtableTotalSpaceInMbParams contains all the parameters to send to the API endpoint for the find config memtable total space in mb operation typically these are written to a http.Request

func NewFindConfigMemtableTotalSpaceInMbParams ¶

func NewFindConfigMemtableTotalSpaceInMbParams() *FindConfigMemtableTotalSpaceInMbParams

NewFindConfigMemtableTotalSpaceInMbParams creates a new FindConfigMemtableTotalSpaceInMbParams object with the default values initialized.

func NewFindConfigMemtableTotalSpaceInMbParamsWithContext ¶

func NewFindConfigMemtableTotalSpaceInMbParamsWithContext(ctx context.Context) *FindConfigMemtableTotalSpaceInMbParams

NewFindConfigMemtableTotalSpaceInMbParamsWithContext creates a new FindConfigMemtableTotalSpaceInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMemtableTotalSpaceInMbParamsWithHTTPClient ¶

func NewFindConfigMemtableTotalSpaceInMbParamsWithHTTPClient(client *http.Client) *FindConfigMemtableTotalSpaceInMbParams

NewFindConfigMemtableTotalSpaceInMbParamsWithHTTPClient creates a new FindConfigMemtableTotalSpaceInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMemtableTotalSpaceInMbParamsWithTimeout ¶

func NewFindConfigMemtableTotalSpaceInMbParamsWithTimeout(timeout time.Duration) *FindConfigMemtableTotalSpaceInMbParams

NewFindConfigMemtableTotalSpaceInMbParamsWithTimeout creates a new FindConfigMemtableTotalSpaceInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMemtableTotalSpaceInMbParams) SetContext ¶

SetContext adds the context to the find config memtable total space in mb params

func (*FindConfigMemtableTotalSpaceInMbParams) SetHTTPClient ¶

func (o *FindConfigMemtableTotalSpaceInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config memtable total space in mb params

func (*FindConfigMemtableTotalSpaceInMbParams) SetTimeout ¶

func (o *FindConfigMemtableTotalSpaceInMbParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config memtable total space in mb params

func (*FindConfigMemtableTotalSpaceInMbParams) WithContext ¶

WithContext adds the context to the find config memtable total space in mb params

func (*FindConfigMemtableTotalSpaceInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config memtable total space in mb params

func (*FindConfigMemtableTotalSpaceInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config memtable total space in mb params

func (*FindConfigMemtableTotalSpaceInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMemtableTotalSpaceInMbReader ¶

type FindConfigMemtableTotalSpaceInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigMemtableTotalSpaceInMbReader is a Reader for the FindConfigMemtableTotalSpaceInMb structure.

func (*FindConfigMemtableTotalSpaceInMbReader) ReadResponse ¶

func (o *FindConfigMemtableTotalSpaceInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigMurmur3PartitionerIgnoreMsbBitsDefault ¶

type FindConfigMurmur3PartitionerIgnoreMsbBitsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigMurmur3PartitionerIgnoreMsbBitsDefault handles this case with default header values.

unexpected error

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsDefault ¶

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsDefault(code int) *FindConfigMurmur3PartitionerIgnoreMsbBitsDefault

NewFindConfigMurmur3PartitionerIgnoreMsbBitsDefault creates a FindConfigMurmur3PartitionerIgnoreMsbBitsDefault with default headers values

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsDefault) Code ¶

Code gets the status code for the find config murmur3 partitioner ignore msb bits default response

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsDefault) Error ¶

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsDefault) GetPayload ¶

type FindConfigMurmur3PartitionerIgnoreMsbBitsOK ¶

type FindConfigMurmur3PartitionerIgnoreMsbBitsOK struct {
	Payload int64
}

FindConfigMurmur3PartitionerIgnoreMsbBitsOK handles this case with default header values.

Config value

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsOK ¶

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsOK() *FindConfigMurmur3PartitionerIgnoreMsbBitsOK

NewFindConfigMurmur3PartitionerIgnoreMsbBitsOK creates a FindConfigMurmur3PartitionerIgnoreMsbBitsOK with default headers values

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsOK) GetPayload ¶

type FindConfigMurmur3PartitionerIgnoreMsbBitsParams ¶

type FindConfigMurmur3PartitionerIgnoreMsbBitsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigMurmur3PartitionerIgnoreMsbBitsParams contains all the parameters to send to the API endpoint for the find config murmur3 partitioner ignore msb bits operation typically these are written to a http.Request

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsParams ¶

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsParams() *FindConfigMurmur3PartitionerIgnoreMsbBitsParams

NewFindConfigMurmur3PartitionerIgnoreMsbBitsParams creates a new FindConfigMurmur3PartitionerIgnoreMsbBitsParams object with the default values initialized.

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithContext ¶

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithContext(ctx context.Context) *FindConfigMurmur3PartitionerIgnoreMsbBitsParams

NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithContext creates a new FindConfigMurmur3PartitionerIgnoreMsbBitsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithHTTPClient ¶

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithHTTPClient(client *http.Client) *FindConfigMurmur3PartitionerIgnoreMsbBitsParams

NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithHTTPClient creates a new FindConfigMurmur3PartitionerIgnoreMsbBitsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithTimeout ¶

func NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithTimeout(timeout time.Duration) *FindConfigMurmur3PartitionerIgnoreMsbBitsParams

NewFindConfigMurmur3PartitionerIgnoreMsbBitsParamsWithTimeout creates a new FindConfigMurmur3PartitionerIgnoreMsbBitsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsParams) SetContext ¶

SetContext adds the context to the find config murmur3 partitioner ignore msb bits params

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config murmur3 partitioner ignore msb bits params

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config murmur3 partitioner ignore msb bits params

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsParams) WithContext ¶

WithContext adds the context to the find config murmur3 partitioner ignore msb bits params

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config murmur3 partitioner ignore msb bits params

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config murmur3 partitioner ignore msb bits params

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigMurmur3PartitionerIgnoreMsbBitsReader ¶

type FindConfigMurmur3PartitionerIgnoreMsbBitsReader struct {
	// contains filtered or unexported fields
}

FindConfigMurmur3PartitionerIgnoreMsbBitsReader is a Reader for the FindConfigMurmur3PartitionerIgnoreMsbBits structure.

func (*FindConfigMurmur3PartitionerIgnoreMsbBitsReader) ReadResponse ¶

func (o *FindConfigMurmur3PartitionerIgnoreMsbBitsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigNativeTransportMaxFrameSizeInMbDefault ¶

type FindConfigNativeTransportMaxFrameSizeInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigNativeTransportMaxFrameSizeInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigNativeTransportMaxFrameSizeInMbDefault ¶

func NewFindConfigNativeTransportMaxFrameSizeInMbDefault(code int) *FindConfigNativeTransportMaxFrameSizeInMbDefault

NewFindConfigNativeTransportMaxFrameSizeInMbDefault creates a FindConfigNativeTransportMaxFrameSizeInMbDefault with default headers values

func (*FindConfigNativeTransportMaxFrameSizeInMbDefault) Code ¶

Code gets the status code for the find config native transport max frame size in mb default response

func (*FindConfigNativeTransportMaxFrameSizeInMbDefault) Error ¶

func (*FindConfigNativeTransportMaxFrameSizeInMbDefault) GetPayload ¶

type FindConfigNativeTransportMaxFrameSizeInMbOK ¶

type FindConfigNativeTransportMaxFrameSizeInMbOK struct {
	Payload int64
}

FindConfigNativeTransportMaxFrameSizeInMbOK handles this case with default header values.

Config value

func NewFindConfigNativeTransportMaxFrameSizeInMbOK ¶

func NewFindConfigNativeTransportMaxFrameSizeInMbOK() *FindConfigNativeTransportMaxFrameSizeInMbOK

NewFindConfigNativeTransportMaxFrameSizeInMbOK creates a FindConfigNativeTransportMaxFrameSizeInMbOK with default headers values

func (*FindConfigNativeTransportMaxFrameSizeInMbOK) GetPayload ¶

type FindConfigNativeTransportMaxFrameSizeInMbParams ¶

type FindConfigNativeTransportMaxFrameSizeInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigNativeTransportMaxFrameSizeInMbParams contains all the parameters to send to the API endpoint for the find config native transport max frame size in mb operation typically these are written to a http.Request

func NewFindConfigNativeTransportMaxFrameSizeInMbParams ¶

func NewFindConfigNativeTransportMaxFrameSizeInMbParams() *FindConfigNativeTransportMaxFrameSizeInMbParams

NewFindConfigNativeTransportMaxFrameSizeInMbParams creates a new FindConfigNativeTransportMaxFrameSizeInMbParams object with the default values initialized.

func NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithContext ¶

func NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithContext(ctx context.Context) *FindConfigNativeTransportMaxFrameSizeInMbParams

NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithContext creates a new FindConfigNativeTransportMaxFrameSizeInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithHTTPClient ¶

func NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithHTTPClient(client *http.Client) *FindConfigNativeTransportMaxFrameSizeInMbParams

NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithHTTPClient creates a new FindConfigNativeTransportMaxFrameSizeInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithTimeout ¶

func NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithTimeout(timeout time.Duration) *FindConfigNativeTransportMaxFrameSizeInMbParams

NewFindConfigNativeTransportMaxFrameSizeInMbParamsWithTimeout creates a new FindConfigNativeTransportMaxFrameSizeInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigNativeTransportMaxFrameSizeInMbParams) SetContext ¶

SetContext adds the context to the find config native transport max frame size in mb params

func (*FindConfigNativeTransportMaxFrameSizeInMbParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config native transport max frame size in mb params

func (*FindConfigNativeTransportMaxFrameSizeInMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config native transport max frame size in mb params

func (*FindConfigNativeTransportMaxFrameSizeInMbParams) WithContext ¶

WithContext adds the context to the find config native transport max frame size in mb params

func (*FindConfigNativeTransportMaxFrameSizeInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config native transport max frame size in mb params

func (*FindConfigNativeTransportMaxFrameSizeInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config native transport max frame size in mb params

func (*FindConfigNativeTransportMaxFrameSizeInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigNativeTransportMaxFrameSizeInMbReader ¶

type FindConfigNativeTransportMaxFrameSizeInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigNativeTransportMaxFrameSizeInMbReader is a Reader for the FindConfigNativeTransportMaxFrameSizeInMb structure.

func (*FindConfigNativeTransportMaxFrameSizeInMbReader) ReadResponse ¶

func (o *FindConfigNativeTransportMaxFrameSizeInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigNativeTransportMaxThreadsDefault ¶

type FindConfigNativeTransportMaxThreadsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigNativeTransportMaxThreadsDefault handles this case with default header values.

unexpected error

func NewFindConfigNativeTransportMaxThreadsDefault ¶

func NewFindConfigNativeTransportMaxThreadsDefault(code int) *FindConfigNativeTransportMaxThreadsDefault

NewFindConfigNativeTransportMaxThreadsDefault creates a FindConfigNativeTransportMaxThreadsDefault with default headers values

func (*FindConfigNativeTransportMaxThreadsDefault) Code ¶

Code gets the status code for the find config native transport max threads default response

func (*FindConfigNativeTransportMaxThreadsDefault) Error ¶

func (*FindConfigNativeTransportMaxThreadsDefault) GetPayload ¶

type FindConfigNativeTransportMaxThreadsOK ¶

type FindConfigNativeTransportMaxThreadsOK struct {
	Payload int64
}

FindConfigNativeTransportMaxThreadsOK handles this case with default header values.

Config value

func NewFindConfigNativeTransportMaxThreadsOK ¶

func NewFindConfigNativeTransportMaxThreadsOK() *FindConfigNativeTransportMaxThreadsOK

NewFindConfigNativeTransportMaxThreadsOK creates a FindConfigNativeTransportMaxThreadsOK with default headers values

func (*FindConfigNativeTransportMaxThreadsOK) GetPayload ¶

type FindConfigNativeTransportMaxThreadsParams ¶

type FindConfigNativeTransportMaxThreadsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigNativeTransportMaxThreadsParams contains all the parameters to send to the API endpoint for the find config native transport max threads operation typically these are written to a http.Request

func NewFindConfigNativeTransportMaxThreadsParams ¶

func NewFindConfigNativeTransportMaxThreadsParams() *FindConfigNativeTransportMaxThreadsParams

NewFindConfigNativeTransportMaxThreadsParams creates a new FindConfigNativeTransportMaxThreadsParams object with the default values initialized.

func NewFindConfigNativeTransportMaxThreadsParamsWithContext ¶

func NewFindConfigNativeTransportMaxThreadsParamsWithContext(ctx context.Context) *FindConfigNativeTransportMaxThreadsParams

NewFindConfigNativeTransportMaxThreadsParamsWithContext creates a new FindConfigNativeTransportMaxThreadsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigNativeTransportMaxThreadsParamsWithHTTPClient ¶

func NewFindConfigNativeTransportMaxThreadsParamsWithHTTPClient(client *http.Client) *FindConfigNativeTransportMaxThreadsParams

NewFindConfigNativeTransportMaxThreadsParamsWithHTTPClient creates a new FindConfigNativeTransportMaxThreadsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigNativeTransportMaxThreadsParamsWithTimeout ¶

func NewFindConfigNativeTransportMaxThreadsParamsWithTimeout(timeout time.Duration) *FindConfigNativeTransportMaxThreadsParams

NewFindConfigNativeTransportMaxThreadsParamsWithTimeout creates a new FindConfigNativeTransportMaxThreadsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigNativeTransportMaxThreadsParams) SetContext ¶

SetContext adds the context to the find config native transport max threads params

func (*FindConfigNativeTransportMaxThreadsParams) SetHTTPClient ¶

func (o *FindConfigNativeTransportMaxThreadsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config native transport max threads params

func (*FindConfigNativeTransportMaxThreadsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config native transport max threads params

func (*FindConfigNativeTransportMaxThreadsParams) WithContext ¶

WithContext adds the context to the find config native transport max threads params

func (*FindConfigNativeTransportMaxThreadsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config native transport max threads params

func (*FindConfigNativeTransportMaxThreadsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config native transport max threads params

func (*FindConfigNativeTransportMaxThreadsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigNativeTransportMaxThreadsReader ¶

type FindConfigNativeTransportMaxThreadsReader struct {
	// contains filtered or unexported fields
}

FindConfigNativeTransportMaxThreadsReader is a Reader for the FindConfigNativeTransportMaxThreads structure.

func (*FindConfigNativeTransportMaxThreadsReader) ReadResponse ¶

func (o *FindConfigNativeTransportMaxThreadsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigNativeTransportPortDefault ¶

type FindConfigNativeTransportPortDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigNativeTransportPortDefault handles this case with default header values.

unexpected error

func NewFindConfigNativeTransportPortDefault ¶

func NewFindConfigNativeTransportPortDefault(code int) *FindConfigNativeTransportPortDefault

NewFindConfigNativeTransportPortDefault creates a FindConfigNativeTransportPortDefault with default headers values

func (*FindConfigNativeTransportPortDefault) Code ¶

Code gets the status code for the find config native transport port default response

func (*FindConfigNativeTransportPortDefault) Error ¶

func (*FindConfigNativeTransportPortDefault) GetPayload ¶

type FindConfigNativeTransportPortOK ¶

type FindConfigNativeTransportPortOK struct {
	Payload int64
}

FindConfigNativeTransportPortOK handles this case with default header values.

Config value

func NewFindConfigNativeTransportPortOK ¶

func NewFindConfigNativeTransportPortOK() *FindConfigNativeTransportPortOK

NewFindConfigNativeTransportPortOK creates a FindConfigNativeTransportPortOK with default headers values

func (*FindConfigNativeTransportPortOK) GetPayload ¶

func (o *FindConfigNativeTransportPortOK) GetPayload() int64

type FindConfigNativeTransportPortParams ¶

type FindConfigNativeTransportPortParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigNativeTransportPortParams contains all the parameters to send to the API endpoint for the find config native transport port operation typically these are written to a http.Request

func NewFindConfigNativeTransportPortParams ¶

func NewFindConfigNativeTransportPortParams() *FindConfigNativeTransportPortParams

NewFindConfigNativeTransportPortParams creates a new FindConfigNativeTransportPortParams object with the default values initialized.

func NewFindConfigNativeTransportPortParamsWithContext ¶

func NewFindConfigNativeTransportPortParamsWithContext(ctx context.Context) *FindConfigNativeTransportPortParams

NewFindConfigNativeTransportPortParamsWithContext creates a new FindConfigNativeTransportPortParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigNativeTransportPortParamsWithHTTPClient ¶

func NewFindConfigNativeTransportPortParamsWithHTTPClient(client *http.Client) *FindConfigNativeTransportPortParams

NewFindConfigNativeTransportPortParamsWithHTTPClient creates a new FindConfigNativeTransportPortParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigNativeTransportPortParamsWithTimeout ¶

func NewFindConfigNativeTransportPortParamsWithTimeout(timeout time.Duration) *FindConfigNativeTransportPortParams

NewFindConfigNativeTransportPortParamsWithTimeout creates a new FindConfigNativeTransportPortParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigNativeTransportPortParams) SetContext ¶

SetContext adds the context to the find config native transport port params

func (*FindConfigNativeTransportPortParams) SetHTTPClient ¶

func (o *FindConfigNativeTransportPortParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config native transport port params

func (*FindConfigNativeTransportPortParams) SetTimeout ¶

func (o *FindConfigNativeTransportPortParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config native transport port params

func (*FindConfigNativeTransportPortParams) WithContext ¶

WithContext adds the context to the find config native transport port params

func (*FindConfigNativeTransportPortParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config native transport port params

func (*FindConfigNativeTransportPortParams) WithTimeout ¶

WithTimeout adds the timeout to the find config native transport port params

func (*FindConfigNativeTransportPortParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigNativeTransportPortReader ¶

type FindConfigNativeTransportPortReader struct {
	// contains filtered or unexported fields
}

FindConfigNativeTransportPortReader is a Reader for the FindConfigNativeTransportPort structure.

func (*FindConfigNativeTransportPortReader) ReadResponse ¶

func (o *FindConfigNativeTransportPortReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigNativeTransportPortSslDefault ¶

type FindConfigNativeTransportPortSslDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigNativeTransportPortSslDefault handles this case with default header values.

unexpected error

func NewFindConfigNativeTransportPortSslDefault ¶

func NewFindConfigNativeTransportPortSslDefault(code int) *FindConfigNativeTransportPortSslDefault

NewFindConfigNativeTransportPortSslDefault creates a FindConfigNativeTransportPortSslDefault with default headers values

func (*FindConfigNativeTransportPortSslDefault) Code ¶

Code gets the status code for the find config native transport port ssl default response

func (*FindConfigNativeTransportPortSslDefault) Error ¶

func (*FindConfigNativeTransportPortSslDefault) GetPayload ¶

type FindConfigNativeTransportPortSslOK ¶

type FindConfigNativeTransportPortSslOK struct {
	Payload int64
}

FindConfigNativeTransportPortSslOK handles this case with default header values.

Config value

func NewFindConfigNativeTransportPortSslOK ¶

func NewFindConfigNativeTransportPortSslOK() *FindConfigNativeTransportPortSslOK

NewFindConfigNativeTransportPortSslOK creates a FindConfigNativeTransportPortSslOK with default headers values

func (*FindConfigNativeTransportPortSslOK) GetPayload ¶

func (o *FindConfigNativeTransportPortSslOK) GetPayload() int64

type FindConfigNativeTransportPortSslParams ¶

type FindConfigNativeTransportPortSslParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigNativeTransportPortSslParams contains all the parameters to send to the API endpoint for the find config native transport port ssl operation typically these are written to a http.Request

func NewFindConfigNativeTransportPortSslParams ¶

func NewFindConfigNativeTransportPortSslParams() *FindConfigNativeTransportPortSslParams

NewFindConfigNativeTransportPortSslParams creates a new FindConfigNativeTransportPortSslParams object with the default values initialized.

func NewFindConfigNativeTransportPortSslParamsWithContext ¶

func NewFindConfigNativeTransportPortSslParamsWithContext(ctx context.Context) *FindConfigNativeTransportPortSslParams

NewFindConfigNativeTransportPortSslParamsWithContext creates a new FindConfigNativeTransportPortSslParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigNativeTransportPortSslParamsWithHTTPClient ¶

func NewFindConfigNativeTransportPortSslParamsWithHTTPClient(client *http.Client) *FindConfigNativeTransportPortSslParams

NewFindConfigNativeTransportPortSslParamsWithHTTPClient creates a new FindConfigNativeTransportPortSslParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigNativeTransportPortSslParamsWithTimeout ¶

func NewFindConfigNativeTransportPortSslParamsWithTimeout(timeout time.Duration) *FindConfigNativeTransportPortSslParams

NewFindConfigNativeTransportPortSslParamsWithTimeout creates a new FindConfigNativeTransportPortSslParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigNativeTransportPortSslParams) SetContext ¶

SetContext adds the context to the find config native transport port ssl params

func (*FindConfigNativeTransportPortSslParams) SetHTTPClient ¶

func (o *FindConfigNativeTransportPortSslParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config native transport port ssl params

func (*FindConfigNativeTransportPortSslParams) SetTimeout ¶

func (o *FindConfigNativeTransportPortSslParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config native transport port ssl params

func (*FindConfigNativeTransportPortSslParams) WithContext ¶

WithContext adds the context to the find config native transport port ssl params

func (*FindConfigNativeTransportPortSslParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config native transport port ssl params

func (*FindConfigNativeTransportPortSslParams) WithTimeout ¶

WithTimeout adds the timeout to the find config native transport port ssl params

func (*FindConfigNativeTransportPortSslParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigNativeTransportPortSslReader ¶

type FindConfigNativeTransportPortSslReader struct {
	// contains filtered or unexported fields
}

FindConfigNativeTransportPortSslReader is a Reader for the FindConfigNativeTransportPortSsl structure.

func (*FindConfigNativeTransportPortSslReader) ReadResponse ¶

func (o *FindConfigNativeTransportPortSslReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigNumTokensDefault ¶

type FindConfigNumTokensDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigNumTokensDefault handles this case with default header values.

unexpected error

func NewFindConfigNumTokensDefault ¶

func NewFindConfigNumTokensDefault(code int) *FindConfigNumTokensDefault

NewFindConfigNumTokensDefault creates a FindConfigNumTokensDefault with default headers values

func (*FindConfigNumTokensDefault) Code ¶

func (o *FindConfigNumTokensDefault) Code() int

Code gets the status code for the find config num tokens default response

func (*FindConfigNumTokensDefault) Error ¶

func (*FindConfigNumTokensDefault) GetPayload ¶

func (o *FindConfigNumTokensDefault) GetPayload() *models.ErrorModel

type FindConfigNumTokensOK ¶

type FindConfigNumTokensOK struct {
	Payload int64
}

FindConfigNumTokensOK handles this case with default header values.

Config value

func NewFindConfigNumTokensOK ¶

func NewFindConfigNumTokensOK() *FindConfigNumTokensOK

NewFindConfigNumTokensOK creates a FindConfigNumTokensOK with default headers values

func (*FindConfigNumTokensOK) GetPayload ¶

func (o *FindConfigNumTokensOK) GetPayload() int64

type FindConfigNumTokensParams ¶

type FindConfigNumTokensParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigNumTokensParams contains all the parameters to send to the API endpoint for the find config num tokens operation typically these are written to a http.Request

func NewFindConfigNumTokensParams ¶

func NewFindConfigNumTokensParams() *FindConfigNumTokensParams

NewFindConfigNumTokensParams creates a new FindConfigNumTokensParams object with the default values initialized.

func NewFindConfigNumTokensParamsWithContext ¶

func NewFindConfigNumTokensParamsWithContext(ctx context.Context) *FindConfigNumTokensParams

NewFindConfigNumTokensParamsWithContext creates a new FindConfigNumTokensParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigNumTokensParamsWithHTTPClient ¶

func NewFindConfigNumTokensParamsWithHTTPClient(client *http.Client) *FindConfigNumTokensParams

NewFindConfigNumTokensParamsWithHTTPClient creates a new FindConfigNumTokensParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigNumTokensParamsWithTimeout ¶

func NewFindConfigNumTokensParamsWithTimeout(timeout time.Duration) *FindConfigNumTokensParams

NewFindConfigNumTokensParamsWithTimeout creates a new FindConfigNumTokensParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigNumTokensParams) SetContext ¶

func (o *FindConfigNumTokensParams) SetContext(ctx context.Context)

SetContext adds the context to the find config num tokens params

func (*FindConfigNumTokensParams) SetHTTPClient ¶

func (o *FindConfigNumTokensParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config num tokens params

func (*FindConfigNumTokensParams) SetTimeout ¶

func (o *FindConfigNumTokensParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config num tokens params

func (*FindConfigNumTokensParams) WithContext ¶

WithContext adds the context to the find config num tokens params

func (*FindConfigNumTokensParams) WithHTTPClient ¶

func (o *FindConfigNumTokensParams) WithHTTPClient(client *http.Client) *FindConfigNumTokensParams

WithHTTPClient adds the HTTPClient to the find config num tokens params

func (*FindConfigNumTokensParams) WithTimeout ¶

WithTimeout adds the timeout to the find config num tokens params

func (*FindConfigNumTokensParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigNumTokensReader ¶

type FindConfigNumTokensReader struct {
	// contains filtered or unexported fields
}

FindConfigNumTokensReader is a Reader for the FindConfigNumTokens structure.

func (*FindConfigNumTokensReader) ReadResponse ¶

func (o *FindConfigNumTokensReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigOverrideDecommissionDefault ¶

type FindConfigOverrideDecommissionDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigOverrideDecommissionDefault handles this case with default header values.

unexpected error

func NewFindConfigOverrideDecommissionDefault ¶

func NewFindConfigOverrideDecommissionDefault(code int) *FindConfigOverrideDecommissionDefault

NewFindConfigOverrideDecommissionDefault creates a FindConfigOverrideDecommissionDefault with default headers values

func (*FindConfigOverrideDecommissionDefault) Code ¶

Code gets the status code for the find config override decommission default response

func (*FindConfigOverrideDecommissionDefault) Error ¶

func (*FindConfigOverrideDecommissionDefault) GetPayload ¶

type FindConfigOverrideDecommissionOK ¶

type FindConfigOverrideDecommissionOK struct {
	Payload bool
}

FindConfigOverrideDecommissionOK handles this case with default header values.

Config value

func NewFindConfigOverrideDecommissionOK ¶

func NewFindConfigOverrideDecommissionOK() *FindConfigOverrideDecommissionOK

NewFindConfigOverrideDecommissionOK creates a FindConfigOverrideDecommissionOK with default headers values

func (*FindConfigOverrideDecommissionOK) GetPayload ¶

func (o *FindConfigOverrideDecommissionOK) GetPayload() bool

type FindConfigOverrideDecommissionParams ¶

type FindConfigOverrideDecommissionParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigOverrideDecommissionParams contains all the parameters to send to the API endpoint for the find config override decommission operation typically these are written to a http.Request

func NewFindConfigOverrideDecommissionParams ¶

func NewFindConfigOverrideDecommissionParams() *FindConfigOverrideDecommissionParams

NewFindConfigOverrideDecommissionParams creates a new FindConfigOverrideDecommissionParams object with the default values initialized.

func NewFindConfigOverrideDecommissionParamsWithContext ¶

func NewFindConfigOverrideDecommissionParamsWithContext(ctx context.Context) *FindConfigOverrideDecommissionParams

NewFindConfigOverrideDecommissionParamsWithContext creates a new FindConfigOverrideDecommissionParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigOverrideDecommissionParamsWithHTTPClient ¶

func NewFindConfigOverrideDecommissionParamsWithHTTPClient(client *http.Client) *FindConfigOverrideDecommissionParams

NewFindConfigOverrideDecommissionParamsWithHTTPClient creates a new FindConfigOverrideDecommissionParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigOverrideDecommissionParamsWithTimeout ¶

func NewFindConfigOverrideDecommissionParamsWithTimeout(timeout time.Duration) *FindConfigOverrideDecommissionParams

NewFindConfigOverrideDecommissionParamsWithTimeout creates a new FindConfigOverrideDecommissionParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigOverrideDecommissionParams) SetContext ¶

SetContext adds the context to the find config override decommission params

func (*FindConfigOverrideDecommissionParams) SetHTTPClient ¶

func (o *FindConfigOverrideDecommissionParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config override decommission params

func (*FindConfigOverrideDecommissionParams) SetTimeout ¶

func (o *FindConfigOverrideDecommissionParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config override decommission params

func (*FindConfigOverrideDecommissionParams) WithContext ¶

WithContext adds the context to the find config override decommission params

func (*FindConfigOverrideDecommissionParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config override decommission params

func (*FindConfigOverrideDecommissionParams) WithTimeout ¶

WithTimeout adds the timeout to the find config override decommission params

func (*FindConfigOverrideDecommissionParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigOverrideDecommissionReader ¶

type FindConfigOverrideDecommissionReader struct {
	// contains filtered or unexported fields
}

FindConfigOverrideDecommissionReader is a Reader for the FindConfigOverrideDecommission structure.

func (*FindConfigOverrideDecommissionReader) ReadResponse ¶

func (o *FindConfigOverrideDecommissionReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPartitionerDefault ¶

type FindConfigPartitionerDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPartitionerDefault handles this case with default header values.

unexpected error

func NewFindConfigPartitionerDefault ¶

func NewFindConfigPartitionerDefault(code int) *FindConfigPartitionerDefault

NewFindConfigPartitionerDefault creates a FindConfigPartitionerDefault with default headers values

func (*FindConfigPartitionerDefault) Code ¶

Code gets the status code for the find config partitioner default response

func (*FindConfigPartitionerDefault) Error ¶

func (*FindConfigPartitionerDefault) GetPayload ¶

type FindConfigPartitionerOK ¶

type FindConfigPartitionerOK struct {
	Payload string
}

FindConfigPartitionerOK handles this case with default header values.

Config value

func NewFindConfigPartitionerOK ¶

func NewFindConfigPartitionerOK() *FindConfigPartitionerOK

NewFindConfigPartitionerOK creates a FindConfigPartitionerOK with default headers values

func (*FindConfigPartitionerOK) GetPayload ¶

func (o *FindConfigPartitionerOK) GetPayload() string

type FindConfigPartitionerParams ¶

type FindConfigPartitionerParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPartitionerParams contains all the parameters to send to the API endpoint for the find config partitioner operation typically these are written to a http.Request

func NewFindConfigPartitionerParams ¶

func NewFindConfigPartitionerParams() *FindConfigPartitionerParams

NewFindConfigPartitionerParams creates a new FindConfigPartitionerParams object with the default values initialized.

func NewFindConfigPartitionerParamsWithContext ¶

func NewFindConfigPartitionerParamsWithContext(ctx context.Context) *FindConfigPartitionerParams

NewFindConfigPartitionerParamsWithContext creates a new FindConfigPartitionerParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPartitionerParamsWithHTTPClient ¶

func NewFindConfigPartitionerParamsWithHTTPClient(client *http.Client) *FindConfigPartitionerParams

NewFindConfigPartitionerParamsWithHTTPClient creates a new FindConfigPartitionerParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPartitionerParamsWithTimeout ¶

func NewFindConfigPartitionerParamsWithTimeout(timeout time.Duration) *FindConfigPartitionerParams

NewFindConfigPartitionerParamsWithTimeout creates a new FindConfigPartitionerParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPartitionerParams) SetContext ¶

func (o *FindConfigPartitionerParams) SetContext(ctx context.Context)

SetContext adds the context to the find config partitioner params

func (*FindConfigPartitionerParams) SetHTTPClient ¶

func (o *FindConfigPartitionerParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config partitioner params

func (*FindConfigPartitionerParams) SetTimeout ¶

func (o *FindConfigPartitionerParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config partitioner params

func (*FindConfigPartitionerParams) WithContext ¶

WithContext adds the context to the find config partitioner params

func (*FindConfigPartitionerParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config partitioner params

func (*FindConfigPartitionerParams) WithTimeout ¶

WithTimeout adds the timeout to the find config partitioner params

func (*FindConfigPartitionerParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPartitionerReader ¶

type FindConfigPartitionerReader struct {
	// contains filtered or unexported fields
}

FindConfigPartitionerReader is a Reader for the FindConfigPartitioner structure.

func (*FindConfigPartitionerReader) ReadResponse ¶

func (o *FindConfigPartitionerReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPermissionsCacheMaxEntriesDefault ¶

type FindConfigPermissionsCacheMaxEntriesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPermissionsCacheMaxEntriesDefault handles this case with default header values.

unexpected error

func NewFindConfigPermissionsCacheMaxEntriesDefault ¶

func NewFindConfigPermissionsCacheMaxEntriesDefault(code int) *FindConfigPermissionsCacheMaxEntriesDefault

NewFindConfigPermissionsCacheMaxEntriesDefault creates a FindConfigPermissionsCacheMaxEntriesDefault with default headers values

func (*FindConfigPermissionsCacheMaxEntriesDefault) Code ¶

Code gets the status code for the find config permissions cache max entries default response

func (*FindConfigPermissionsCacheMaxEntriesDefault) Error ¶

func (*FindConfigPermissionsCacheMaxEntriesDefault) GetPayload ¶

type FindConfigPermissionsCacheMaxEntriesOK ¶

type FindConfigPermissionsCacheMaxEntriesOK struct {
	Payload int64
}

FindConfigPermissionsCacheMaxEntriesOK handles this case with default header values.

Config value

func NewFindConfigPermissionsCacheMaxEntriesOK ¶

func NewFindConfigPermissionsCacheMaxEntriesOK() *FindConfigPermissionsCacheMaxEntriesOK

NewFindConfigPermissionsCacheMaxEntriesOK creates a FindConfigPermissionsCacheMaxEntriesOK with default headers values

func (*FindConfigPermissionsCacheMaxEntriesOK) GetPayload ¶

type FindConfigPermissionsCacheMaxEntriesParams ¶

type FindConfigPermissionsCacheMaxEntriesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPermissionsCacheMaxEntriesParams contains all the parameters to send to the API endpoint for the find config permissions cache max entries operation typically these are written to a http.Request

func NewFindConfigPermissionsCacheMaxEntriesParams ¶

func NewFindConfigPermissionsCacheMaxEntriesParams() *FindConfigPermissionsCacheMaxEntriesParams

NewFindConfigPermissionsCacheMaxEntriesParams creates a new FindConfigPermissionsCacheMaxEntriesParams object with the default values initialized.

func NewFindConfigPermissionsCacheMaxEntriesParamsWithContext ¶

func NewFindConfigPermissionsCacheMaxEntriesParamsWithContext(ctx context.Context) *FindConfigPermissionsCacheMaxEntriesParams

NewFindConfigPermissionsCacheMaxEntriesParamsWithContext creates a new FindConfigPermissionsCacheMaxEntriesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPermissionsCacheMaxEntriesParamsWithHTTPClient ¶

func NewFindConfigPermissionsCacheMaxEntriesParamsWithHTTPClient(client *http.Client) *FindConfigPermissionsCacheMaxEntriesParams

NewFindConfigPermissionsCacheMaxEntriesParamsWithHTTPClient creates a new FindConfigPermissionsCacheMaxEntriesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPermissionsCacheMaxEntriesParamsWithTimeout ¶

func NewFindConfigPermissionsCacheMaxEntriesParamsWithTimeout(timeout time.Duration) *FindConfigPermissionsCacheMaxEntriesParams

NewFindConfigPermissionsCacheMaxEntriesParamsWithTimeout creates a new FindConfigPermissionsCacheMaxEntriesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPermissionsCacheMaxEntriesParams) SetContext ¶

SetContext adds the context to the find config permissions cache max entries params

func (*FindConfigPermissionsCacheMaxEntriesParams) SetHTTPClient ¶

func (o *FindConfigPermissionsCacheMaxEntriesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config permissions cache max entries params

func (*FindConfigPermissionsCacheMaxEntriesParams) SetTimeout ¶

SetTimeout adds the timeout to the find config permissions cache max entries params

func (*FindConfigPermissionsCacheMaxEntriesParams) WithContext ¶

WithContext adds the context to the find config permissions cache max entries params

func (*FindConfigPermissionsCacheMaxEntriesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config permissions cache max entries params

func (*FindConfigPermissionsCacheMaxEntriesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config permissions cache max entries params

func (*FindConfigPermissionsCacheMaxEntriesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPermissionsCacheMaxEntriesReader ¶

type FindConfigPermissionsCacheMaxEntriesReader struct {
	// contains filtered or unexported fields
}

FindConfigPermissionsCacheMaxEntriesReader is a Reader for the FindConfigPermissionsCacheMaxEntries structure.

func (*FindConfigPermissionsCacheMaxEntriesReader) ReadResponse ¶

func (o *FindConfigPermissionsCacheMaxEntriesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPermissionsUpdateIntervalInMsDefault ¶

type FindConfigPermissionsUpdateIntervalInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPermissionsUpdateIntervalInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigPermissionsUpdateIntervalInMsDefault ¶

func NewFindConfigPermissionsUpdateIntervalInMsDefault(code int) *FindConfigPermissionsUpdateIntervalInMsDefault

NewFindConfigPermissionsUpdateIntervalInMsDefault creates a FindConfigPermissionsUpdateIntervalInMsDefault with default headers values

func (*FindConfigPermissionsUpdateIntervalInMsDefault) Code ¶

Code gets the status code for the find config permissions update interval in ms default response

func (*FindConfigPermissionsUpdateIntervalInMsDefault) Error ¶

func (*FindConfigPermissionsUpdateIntervalInMsDefault) GetPayload ¶

type FindConfigPermissionsUpdateIntervalInMsOK ¶

type FindConfigPermissionsUpdateIntervalInMsOK struct {
	Payload int64
}

FindConfigPermissionsUpdateIntervalInMsOK handles this case with default header values.

Config value

func NewFindConfigPermissionsUpdateIntervalInMsOK ¶

func NewFindConfigPermissionsUpdateIntervalInMsOK() *FindConfigPermissionsUpdateIntervalInMsOK

NewFindConfigPermissionsUpdateIntervalInMsOK creates a FindConfigPermissionsUpdateIntervalInMsOK with default headers values

func (*FindConfigPermissionsUpdateIntervalInMsOK) GetPayload ¶

type FindConfigPermissionsUpdateIntervalInMsParams ¶

type FindConfigPermissionsUpdateIntervalInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPermissionsUpdateIntervalInMsParams contains all the parameters to send to the API endpoint for the find config permissions update interval in ms operation typically these are written to a http.Request

func NewFindConfigPermissionsUpdateIntervalInMsParams ¶

func NewFindConfigPermissionsUpdateIntervalInMsParams() *FindConfigPermissionsUpdateIntervalInMsParams

NewFindConfigPermissionsUpdateIntervalInMsParams creates a new FindConfigPermissionsUpdateIntervalInMsParams object with the default values initialized.

func NewFindConfigPermissionsUpdateIntervalInMsParamsWithContext ¶

func NewFindConfigPermissionsUpdateIntervalInMsParamsWithContext(ctx context.Context) *FindConfigPermissionsUpdateIntervalInMsParams

NewFindConfigPermissionsUpdateIntervalInMsParamsWithContext creates a new FindConfigPermissionsUpdateIntervalInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPermissionsUpdateIntervalInMsParamsWithHTTPClient ¶

func NewFindConfigPermissionsUpdateIntervalInMsParamsWithHTTPClient(client *http.Client) *FindConfigPermissionsUpdateIntervalInMsParams

NewFindConfigPermissionsUpdateIntervalInMsParamsWithHTTPClient creates a new FindConfigPermissionsUpdateIntervalInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPermissionsUpdateIntervalInMsParamsWithTimeout ¶

func NewFindConfigPermissionsUpdateIntervalInMsParamsWithTimeout(timeout time.Duration) *FindConfigPermissionsUpdateIntervalInMsParams

NewFindConfigPermissionsUpdateIntervalInMsParamsWithTimeout creates a new FindConfigPermissionsUpdateIntervalInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPermissionsUpdateIntervalInMsParams) SetContext ¶

SetContext adds the context to the find config permissions update interval in ms params

func (*FindConfigPermissionsUpdateIntervalInMsParams) SetHTTPClient ¶

func (o *FindConfigPermissionsUpdateIntervalInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config permissions update interval in ms params

func (*FindConfigPermissionsUpdateIntervalInMsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config permissions update interval in ms params

func (*FindConfigPermissionsUpdateIntervalInMsParams) WithContext ¶

WithContext adds the context to the find config permissions update interval in ms params

func (*FindConfigPermissionsUpdateIntervalInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config permissions update interval in ms params

func (*FindConfigPermissionsUpdateIntervalInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config permissions update interval in ms params

func (*FindConfigPermissionsUpdateIntervalInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPermissionsUpdateIntervalInMsReader ¶

type FindConfigPermissionsUpdateIntervalInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigPermissionsUpdateIntervalInMsReader is a Reader for the FindConfigPermissionsUpdateIntervalInMs structure.

func (*FindConfigPermissionsUpdateIntervalInMsReader) ReadResponse ¶

func (o *FindConfigPermissionsUpdateIntervalInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPermissionsValidityInMsDefault ¶

type FindConfigPermissionsValidityInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPermissionsValidityInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigPermissionsValidityInMsDefault ¶

func NewFindConfigPermissionsValidityInMsDefault(code int) *FindConfigPermissionsValidityInMsDefault

NewFindConfigPermissionsValidityInMsDefault creates a FindConfigPermissionsValidityInMsDefault with default headers values

func (*FindConfigPermissionsValidityInMsDefault) Code ¶

Code gets the status code for the find config permissions validity in ms default response

func (*FindConfigPermissionsValidityInMsDefault) Error ¶

func (*FindConfigPermissionsValidityInMsDefault) GetPayload ¶

type FindConfigPermissionsValidityInMsOK ¶

type FindConfigPermissionsValidityInMsOK struct {
	Payload int64
}

FindConfigPermissionsValidityInMsOK handles this case with default header values.

Config value

func NewFindConfigPermissionsValidityInMsOK ¶

func NewFindConfigPermissionsValidityInMsOK() *FindConfigPermissionsValidityInMsOK

NewFindConfigPermissionsValidityInMsOK creates a FindConfigPermissionsValidityInMsOK with default headers values

func (*FindConfigPermissionsValidityInMsOK) GetPayload ¶

type FindConfigPermissionsValidityInMsParams ¶

type FindConfigPermissionsValidityInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPermissionsValidityInMsParams contains all the parameters to send to the API endpoint for the find config permissions validity in ms operation typically these are written to a http.Request

func NewFindConfigPermissionsValidityInMsParams ¶

func NewFindConfigPermissionsValidityInMsParams() *FindConfigPermissionsValidityInMsParams

NewFindConfigPermissionsValidityInMsParams creates a new FindConfigPermissionsValidityInMsParams object with the default values initialized.

func NewFindConfigPermissionsValidityInMsParamsWithContext ¶

func NewFindConfigPermissionsValidityInMsParamsWithContext(ctx context.Context) *FindConfigPermissionsValidityInMsParams

NewFindConfigPermissionsValidityInMsParamsWithContext creates a new FindConfigPermissionsValidityInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPermissionsValidityInMsParamsWithHTTPClient ¶

func NewFindConfigPermissionsValidityInMsParamsWithHTTPClient(client *http.Client) *FindConfigPermissionsValidityInMsParams

NewFindConfigPermissionsValidityInMsParamsWithHTTPClient creates a new FindConfigPermissionsValidityInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPermissionsValidityInMsParamsWithTimeout ¶

func NewFindConfigPermissionsValidityInMsParamsWithTimeout(timeout time.Duration) *FindConfigPermissionsValidityInMsParams

NewFindConfigPermissionsValidityInMsParamsWithTimeout creates a new FindConfigPermissionsValidityInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPermissionsValidityInMsParams) SetContext ¶

SetContext adds the context to the find config permissions validity in ms params

func (*FindConfigPermissionsValidityInMsParams) SetHTTPClient ¶

func (o *FindConfigPermissionsValidityInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config permissions validity in ms params

func (*FindConfigPermissionsValidityInMsParams) SetTimeout ¶

func (o *FindConfigPermissionsValidityInMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config permissions validity in ms params

func (*FindConfigPermissionsValidityInMsParams) WithContext ¶

WithContext adds the context to the find config permissions validity in ms params

func (*FindConfigPermissionsValidityInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config permissions validity in ms params

func (*FindConfigPermissionsValidityInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config permissions validity in ms params

func (*FindConfigPermissionsValidityInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPermissionsValidityInMsReader ¶

type FindConfigPermissionsValidityInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigPermissionsValidityInMsReader is a Reader for the FindConfigPermissionsValidityInMs structure.

func (*FindConfigPermissionsValidityInMsReader) ReadResponse ¶

func (o *FindConfigPermissionsValidityInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPhiConvictThresholdDefault ¶

type FindConfigPhiConvictThresholdDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPhiConvictThresholdDefault handles this case with default header values.

unexpected error

func NewFindConfigPhiConvictThresholdDefault ¶

func NewFindConfigPhiConvictThresholdDefault(code int) *FindConfigPhiConvictThresholdDefault

NewFindConfigPhiConvictThresholdDefault creates a FindConfigPhiConvictThresholdDefault with default headers values

func (*FindConfigPhiConvictThresholdDefault) Code ¶

Code gets the status code for the find config phi convict threshold default response

func (*FindConfigPhiConvictThresholdDefault) Error ¶

func (*FindConfigPhiConvictThresholdDefault) GetPayload ¶

type FindConfigPhiConvictThresholdOK ¶

type FindConfigPhiConvictThresholdOK struct {
	Payload int64
}

FindConfigPhiConvictThresholdOK handles this case with default header values.

Config value

func NewFindConfigPhiConvictThresholdOK ¶

func NewFindConfigPhiConvictThresholdOK() *FindConfigPhiConvictThresholdOK

NewFindConfigPhiConvictThresholdOK creates a FindConfigPhiConvictThresholdOK with default headers values

func (*FindConfigPhiConvictThresholdOK) GetPayload ¶

func (o *FindConfigPhiConvictThresholdOK) GetPayload() int64

type FindConfigPhiConvictThresholdParams ¶

type FindConfigPhiConvictThresholdParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPhiConvictThresholdParams contains all the parameters to send to the API endpoint for the find config phi convict threshold operation typically these are written to a http.Request

func NewFindConfigPhiConvictThresholdParams ¶

func NewFindConfigPhiConvictThresholdParams() *FindConfigPhiConvictThresholdParams

NewFindConfigPhiConvictThresholdParams creates a new FindConfigPhiConvictThresholdParams object with the default values initialized.

func NewFindConfigPhiConvictThresholdParamsWithContext ¶

func NewFindConfigPhiConvictThresholdParamsWithContext(ctx context.Context) *FindConfigPhiConvictThresholdParams

NewFindConfigPhiConvictThresholdParamsWithContext creates a new FindConfigPhiConvictThresholdParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPhiConvictThresholdParamsWithHTTPClient ¶

func NewFindConfigPhiConvictThresholdParamsWithHTTPClient(client *http.Client) *FindConfigPhiConvictThresholdParams

NewFindConfigPhiConvictThresholdParamsWithHTTPClient creates a new FindConfigPhiConvictThresholdParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPhiConvictThresholdParamsWithTimeout ¶

func NewFindConfigPhiConvictThresholdParamsWithTimeout(timeout time.Duration) *FindConfigPhiConvictThresholdParams

NewFindConfigPhiConvictThresholdParamsWithTimeout creates a new FindConfigPhiConvictThresholdParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPhiConvictThresholdParams) SetContext ¶

SetContext adds the context to the find config phi convict threshold params

func (*FindConfigPhiConvictThresholdParams) SetHTTPClient ¶

func (o *FindConfigPhiConvictThresholdParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config phi convict threshold params

func (*FindConfigPhiConvictThresholdParams) SetTimeout ¶

func (o *FindConfigPhiConvictThresholdParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config phi convict threshold params

func (*FindConfigPhiConvictThresholdParams) WithContext ¶

WithContext adds the context to the find config phi convict threshold params

func (*FindConfigPhiConvictThresholdParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config phi convict threshold params

func (*FindConfigPhiConvictThresholdParams) WithTimeout ¶

WithTimeout adds the timeout to the find config phi convict threshold params

func (*FindConfigPhiConvictThresholdParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPhiConvictThresholdReader ¶

type FindConfigPhiConvictThresholdReader struct {
	// contains filtered or unexported fields
}

FindConfigPhiConvictThresholdReader is a Reader for the FindConfigPhiConvictThreshold structure.

func (*FindConfigPhiConvictThresholdReader) ReadResponse ¶

func (o *FindConfigPhiConvictThresholdReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPreheatKernelPageCacheDefault ¶

type FindConfigPreheatKernelPageCacheDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPreheatKernelPageCacheDefault handles this case with default header values.

unexpected error

func NewFindConfigPreheatKernelPageCacheDefault ¶

func NewFindConfigPreheatKernelPageCacheDefault(code int) *FindConfigPreheatKernelPageCacheDefault

NewFindConfigPreheatKernelPageCacheDefault creates a FindConfigPreheatKernelPageCacheDefault with default headers values

func (*FindConfigPreheatKernelPageCacheDefault) Code ¶

Code gets the status code for the find config preheat kernel page cache default response

func (*FindConfigPreheatKernelPageCacheDefault) Error ¶

func (*FindConfigPreheatKernelPageCacheDefault) GetPayload ¶

type FindConfigPreheatKernelPageCacheOK ¶

type FindConfigPreheatKernelPageCacheOK struct {
	Payload bool
}

FindConfigPreheatKernelPageCacheOK handles this case with default header values.

Config value

func NewFindConfigPreheatKernelPageCacheOK ¶

func NewFindConfigPreheatKernelPageCacheOK() *FindConfigPreheatKernelPageCacheOK

NewFindConfigPreheatKernelPageCacheOK creates a FindConfigPreheatKernelPageCacheOK with default headers values

func (*FindConfigPreheatKernelPageCacheOK) GetPayload ¶

func (o *FindConfigPreheatKernelPageCacheOK) GetPayload() bool

type FindConfigPreheatKernelPageCacheParams ¶

type FindConfigPreheatKernelPageCacheParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPreheatKernelPageCacheParams contains all the parameters to send to the API endpoint for the find config preheat kernel page cache operation typically these are written to a http.Request

func NewFindConfigPreheatKernelPageCacheParams ¶

func NewFindConfigPreheatKernelPageCacheParams() *FindConfigPreheatKernelPageCacheParams

NewFindConfigPreheatKernelPageCacheParams creates a new FindConfigPreheatKernelPageCacheParams object with the default values initialized.

func NewFindConfigPreheatKernelPageCacheParamsWithContext ¶

func NewFindConfigPreheatKernelPageCacheParamsWithContext(ctx context.Context) *FindConfigPreheatKernelPageCacheParams

NewFindConfigPreheatKernelPageCacheParamsWithContext creates a new FindConfigPreheatKernelPageCacheParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPreheatKernelPageCacheParamsWithHTTPClient ¶

func NewFindConfigPreheatKernelPageCacheParamsWithHTTPClient(client *http.Client) *FindConfigPreheatKernelPageCacheParams

NewFindConfigPreheatKernelPageCacheParamsWithHTTPClient creates a new FindConfigPreheatKernelPageCacheParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPreheatKernelPageCacheParamsWithTimeout ¶

func NewFindConfigPreheatKernelPageCacheParamsWithTimeout(timeout time.Duration) *FindConfigPreheatKernelPageCacheParams

NewFindConfigPreheatKernelPageCacheParamsWithTimeout creates a new FindConfigPreheatKernelPageCacheParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPreheatKernelPageCacheParams) SetContext ¶

SetContext adds the context to the find config preheat kernel page cache params

func (*FindConfigPreheatKernelPageCacheParams) SetHTTPClient ¶

func (o *FindConfigPreheatKernelPageCacheParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config preheat kernel page cache params

func (*FindConfigPreheatKernelPageCacheParams) SetTimeout ¶

func (o *FindConfigPreheatKernelPageCacheParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config preheat kernel page cache params

func (*FindConfigPreheatKernelPageCacheParams) WithContext ¶

WithContext adds the context to the find config preheat kernel page cache params

func (*FindConfigPreheatKernelPageCacheParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config preheat kernel page cache params

func (*FindConfigPreheatKernelPageCacheParams) WithTimeout ¶

WithTimeout adds the timeout to the find config preheat kernel page cache params

func (*FindConfigPreheatKernelPageCacheParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPreheatKernelPageCacheReader ¶

type FindConfigPreheatKernelPageCacheReader struct {
	// contains filtered or unexported fields
}

FindConfigPreheatKernelPageCacheReader is a Reader for the FindConfigPreheatKernelPageCache structure.

func (*FindConfigPreheatKernelPageCacheReader) ReadResponse ¶

func (o *FindConfigPreheatKernelPageCacheReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPrometheusAddressDefault ¶

type FindConfigPrometheusAddressDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPrometheusAddressDefault handles this case with default header values.

unexpected error

func NewFindConfigPrometheusAddressDefault ¶

func NewFindConfigPrometheusAddressDefault(code int) *FindConfigPrometheusAddressDefault

NewFindConfigPrometheusAddressDefault creates a FindConfigPrometheusAddressDefault with default headers values

func (*FindConfigPrometheusAddressDefault) Code ¶

Code gets the status code for the find config prometheus address default response

func (*FindConfigPrometheusAddressDefault) Error ¶

func (*FindConfigPrometheusAddressDefault) GetPayload ¶

type FindConfigPrometheusAddressOK ¶

type FindConfigPrometheusAddressOK struct {
	Payload string
}

FindConfigPrometheusAddressOK handles this case with default header values.

Config value

func NewFindConfigPrometheusAddressOK ¶

func NewFindConfigPrometheusAddressOK() *FindConfigPrometheusAddressOK

NewFindConfigPrometheusAddressOK creates a FindConfigPrometheusAddressOK with default headers values

func (*FindConfigPrometheusAddressOK) GetPayload ¶

func (o *FindConfigPrometheusAddressOK) GetPayload() string

type FindConfigPrometheusAddressParams ¶

type FindConfigPrometheusAddressParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPrometheusAddressParams contains all the parameters to send to the API endpoint for the find config prometheus address operation typically these are written to a http.Request

func NewFindConfigPrometheusAddressParams ¶

func NewFindConfigPrometheusAddressParams() *FindConfigPrometheusAddressParams

NewFindConfigPrometheusAddressParams creates a new FindConfigPrometheusAddressParams object with the default values initialized.

func NewFindConfigPrometheusAddressParamsWithContext ¶

func NewFindConfigPrometheusAddressParamsWithContext(ctx context.Context) *FindConfigPrometheusAddressParams

NewFindConfigPrometheusAddressParamsWithContext creates a new FindConfigPrometheusAddressParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPrometheusAddressParamsWithHTTPClient ¶

func NewFindConfigPrometheusAddressParamsWithHTTPClient(client *http.Client) *FindConfigPrometheusAddressParams

NewFindConfigPrometheusAddressParamsWithHTTPClient creates a new FindConfigPrometheusAddressParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPrometheusAddressParamsWithTimeout ¶

func NewFindConfigPrometheusAddressParamsWithTimeout(timeout time.Duration) *FindConfigPrometheusAddressParams

NewFindConfigPrometheusAddressParamsWithTimeout creates a new FindConfigPrometheusAddressParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPrometheusAddressParams) SetContext ¶

SetContext adds the context to the find config prometheus address params

func (*FindConfigPrometheusAddressParams) SetHTTPClient ¶

func (o *FindConfigPrometheusAddressParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config prometheus address params

func (*FindConfigPrometheusAddressParams) SetTimeout ¶

func (o *FindConfigPrometheusAddressParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config prometheus address params

func (*FindConfigPrometheusAddressParams) WithContext ¶

WithContext adds the context to the find config prometheus address params

func (*FindConfigPrometheusAddressParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config prometheus address params

func (*FindConfigPrometheusAddressParams) WithTimeout ¶

WithTimeout adds the timeout to the find config prometheus address params

func (*FindConfigPrometheusAddressParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPrometheusAddressReader ¶

type FindConfigPrometheusAddressReader struct {
	// contains filtered or unexported fields
}

FindConfigPrometheusAddressReader is a Reader for the FindConfigPrometheusAddress structure.

func (*FindConfigPrometheusAddressReader) ReadResponse ¶

func (o *FindConfigPrometheusAddressReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPrometheusPortDefault ¶

type FindConfigPrometheusPortDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPrometheusPortDefault handles this case with default header values.

unexpected error

func NewFindConfigPrometheusPortDefault ¶

func NewFindConfigPrometheusPortDefault(code int) *FindConfigPrometheusPortDefault

NewFindConfigPrometheusPortDefault creates a FindConfigPrometheusPortDefault with default headers values

func (*FindConfigPrometheusPortDefault) Code ¶

Code gets the status code for the find config prometheus port default response

func (*FindConfigPrometheusPortDefault) Error ¶

func (*FindConfigPrometheusPortDefault) GetPayload ¶

type FindConfigPrometheusPortOK ¶

type FindConfigPrometheusPortOK struct {
	Payload int64
}

FindConfigPrometheusPortOK handles this case with default header values.

Config value

func NewFindConfigPrometheusPortOK ¶

func NewFindConfigPrometheusPortOK() *FindConfigPrometheusPortOK

NewFindConfigPrometheusPortOK creates a FindConfigPrometheusPortOK with default headers values

func (*FindConfigPrometheusPortOK) GetPayload ¶

func (o *FindConfigPrometheusPortOK) GetPayload() int64

type FindConfigPrometheusPortParams ¶

type FindConfigPrometheusPortParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPrometheusPortParams contains all the parameters to send to the API endpoint for the find config prometheus port operation typically these are written to a http.Request

func NewFindConfigPrometheusPortParams ¶

func NewFindConfigPrometheusPortParams() *FindConfigPrometheusPortParams

NewFindConfigPrometheusPortParams creates a new FindConfigPrometheusPortParams object with the default values initialized.

func NewFindConfigPrometheusPortParamsWithContext ¶

func NewFindConfigPrometheusPortParamsWithContext(ctx context.Context) *FindConfigPrometheusPortParams

NewFindConfigPrometheusPortParamsWithContext creates a new FindConfigPrometheusPortParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPrometheusPortParamsWithHTTPClient ¶

func NewFindConfigPrometheusPortParamsWithHTTPClient(client *http.Client) *FindConfigPrometheusPortParams

NewFindConfigPrometheusPortParamsWithHTTPClient creates a new FindConfigPrometheusPortParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPrometheusPortParamsWithTimeout ¶

func NewFindConfigPrometheusPortParamsWithTimeout(timeout time.Duration) *FindConfigPrometheusPortParams

NewFindConfigPrometheusPortParamsWithTimeout creates a new FindConfigPrometheusPortParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPrometheusPortParams) SetContext ¶

func (o *FindConfigPrometheusPortParams) SetContext(ctx context.Context)

SetContext adds the context to the find config prometheus port params

func (*FindConfigPrometheusPortParams) SetHTTPClient ¶

func (o *FindConfigPrometheusPortParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config prometheus port params

func (*FindConfigPrometheusPortParams) SetTimeout ¶

func (o *FindConfigPrometheusPortParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config prometheus port params

func (*FindConfigPrometheusPortParams) WithContext ¶

WithContext adds the context to the find config prometheus port params

func (*FindConfigPrometheusPortParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config prometheus port params

func (*FindConfigPrometheusPortParams) WithTimeout ¶

WithTimeout adds the timeout to the find config prometheus port params

func (*FindConfigPrometheusPortParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPrometheusPortReader ¶

type FindConfigPrometheusPortReader struct {
	// contains filtered or unexported fields
}

FindConfigPrometheusPortReader is a Reader for the FindConfigPrometheusPort structure.

func (*FindConfigPrometheusPortReader) ReadResponse ¶

func (o *FindConfigPrometheusPortReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigPrometheusPrefixDefault ¶

type FindConfigPrometheusPrefixDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigPrometheusPrefixDefault handles this case with default header values.

unexpected error

func NewFindConfigPrometheusPrefixDefault ¶

func NewFindConfigPrometheusPrefixDefault(code int) *FindConfigPrometheusPrefixDefault

NewFindConfigPrometheusPrefixDefault creates a FindConfigPrometheusPrefixDefault with default headers values

func (*FindConfigPrometheusPrefixDefault) Code ¶

Code gets the status code for the find config prometheus prefix default response

func (*FindConfigPrometheusPrefixDefault) Error ¶

func (*FindConfigPrometheusPrefixDefault) GetPayload ¶

type FindConfigPrometheusPrefixOK ¶

type FindConfigPrometheusPrefixOK struct {
	Payload string
}

FindConfigPrometheusPrefixOK handles this case with default header values.

Config value

func NewFindConfigPrometheusPrefixOK ¶

func NewFindConfigPrometheusPrefixOK() *FindConfigPrometheusPrefixOK

NewFindConfigPrometheusPrefixOK creates a FindConfigPrometheusPrefixOK with default headers values

func (*FindConfigPrometheusPrefixOK) GetPayload ¶

func (o *FindConfigPrometheusPrefixOK) GetPayload() string

type FindConfigPrometheusPrefixParams ¶

type FindConfigPrometheusPrefixParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigPrometheusPrefixParams contains all the parameters to send to the API endpoint for the find config prometheus prefix operation typically these are written to a http.Request

func NewFindConfigPrometheusPrefixParams ¶

func NewFindConfigPrometheusPrefixParams() *FindConfigPrometheusPrefixParams

NewFindConfigPrometheusPrefixParams creates a new FindConfigPrometheusPrefixParams object with the default values initialized.

func NewFindConfigPrometheusPrefixParamsWithContext ¶

func NewFindConfigPrometheusPrefixParamsWithContext(ctx context.Context) *FindConfigPrometheusPrefixParams

NewFindConfigPrometheusPrefixParamsWithContext creates a new FindConfigPrometheusPrefixParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigPrometheusPrefixParamsWithHTTPClient ¶

func NewFindConfigPrometheusPrefixParamsWithHTTPClient(client *http.Client) *FindConfigPrometheusPrefixParams

NewFindConfigPrometheusPrefixParamsWithHTTPClient creates a new FindConfigPrometheusPrefixParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigPrometheusPrefixParamsWithTimeout ¶

func NewFindConfigPrometheusPrefixParamsWithTimeout(timeout time.Duration) *FindConfigPrometheusPrefixParams

NewFindConfigPrometheusPrefixParamsWithTimeout creates a new FindConfigPrometheusPrefixParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigPrometheusPrefixParams) SetContext ¶

SetContext adds the context to the find config prometheus prefix params

func (*FindConfigPrometheusPrefixParams) SetHTTPClient ¶

func (o *FindConfigPrometheusPrefixParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config prometheus prefix params

func (*FindConfigPrometheusPrefixParams) SetTimeout ¶

func (o *FindConfigPrometheusPrefixParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config prometheus prefix params

func (*FindConfigPrometheusPrefixParams) WithContext ¶

WithContext adds the context to the find config prometheus prefix params

func (*FindConfigPrometheusPrefixParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config prometheus prefix params

func (*FindConfigPrometheusPrefixParams) WithTimeout ¶

WithTimeout adds the timeout to the find config prometheus prefix params

func (*FindConfigPrometheusPrefixParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigPrometheusPrefixReader ¶

type FindConfigPrometheusPrefixReader struct {
	// contains filtered or unexported fields
}

FindConfigPrometheusPrefixReader is a Reader for the FindConfigPrometheusPrefix structure.

func (*FindConfigPrometheusPrefixReader) ReadResponse ¶

func (o *FindConfigPrometheusPrefixReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCAddressDefault ¶

type FindConfigRPCAddressDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCAddressDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCAddressDefault ¶

func NewFindConfigRPCAddressDefault(code int) *FindConfigRPCAddressDefault

NewFindConfigRPCAddressDefault creates a FindConfigRPCAddressDefault with default headers values

func (*FindConfigRPCAddressDefault) Code ¶

func (o *FindConfigRPCAddressDefault) Code() int

Code gets the status code for the find config rpc address default response

func (*FindConfigRPCAddressDefault) Error ¶

func (*FindConfigRPCAddressDefault) GetPayload ¶

type FindConfigRPCAddressOK ¶

type FindConfigRPCAddressOK struct {
	Payload string
}

FindConfigRPCAddressOK handles this case with default header values.

Config value

func NewFindConfigRPCAddressOK ¶

func NewFindConfigRPCAddressOK() *FindConfigRPCAddressOK

NewFindConfigRPCAddressOK creates a FindConfigRPCAddressOK with default headers values

func (*FindConfigRPCAddressOK) GetPayload ¶

func (o *FindConfigRPCAddressOK) GetPayload() string

type FindConfigRPCAddressParams ¶

type FindConfigRPCAddressParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCAddressParams contains all the parameters to send to the API endpoint for the find config rpc address operation typically these are written to a http.Request

func NewFindConfigRPCAddressParams ¶

func NewFindConfigRPCAddressParams() *FindConfigRPCAddressParams

NewFindConfigRPCAddressParams creates a new FindConfigRPCAddressParams object with the default values initialized.

func NewFindConfigRPCAddressParamsWithContext ¶

func NewFindConfigRPCAddressParamsWithContext(ctx context.Context) *FindConfigRPCAddressParams

NewFindConfigRPCAddressParamsWithContext creates a new FindConfigRPCAddressParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCAddressParamsWithHTTPClient ¶

func NewFindConfigRPCAddressParamsWithHTTPClient(client *http.Client) *FindConfigRPCAddressParams

NewFindConfigRPCAddressParamsWithHTTPClient creates a new FindConfigRPCAddressParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCAddressParamsWithTimeout ¶

func NewFindConfigRPCAddressParamsWithTimeout(timeout time.Duration) *FindConfigRPCAddressParams

NewFindConfigRPCAddressParamsWithTimeout creates a new FindConfigRPCAddressParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCAddressParams) SetContext ¶

func (o *FindConfigRPCAddressParams) SetContext(ctx context.Context)

SetContext adds the context to the find config rpc address params

func (*FindConfigRPCAddressParams) SetHTTPClient ¶

func (o *FindConfigRPCAddressParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc address params

func (*FindConfigRPCAddressParams) SetTimeout ¶

func (o *FindConfigRPCAddressParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc address params

func (*FindConfigRPCAddressParams) WithContext ¶

WithContext adds the context to the find config rpc address params

func (*FindConfigRPCAddressParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config rpc address params

func (*FindConfigRPCAddressParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc address params

func (*FindConfigRPCAddressParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCAddressReader ¶

type FindConfigRPCAddressReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCAddressReader is a Reader for the FindConfigRPCAddress structure.

func (*FindConfigRPCAddressReader) ReadResponse ¶

func (o *FindConfigRPCAddressReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCInterfaceDefault ¶

type FindConfigRPCInterfaceDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCInterfaceDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCInterfaceDefault ¶

func NewFindConfigRPCInterfaceDefault(code int) *FindConfigRPCInterfaceDefault

NewFindConfigRPCInterfaceDefault creates a FindConfigRPCInterfaceDefault with default headers values

func (*FindConfigRPCInterfaceDefault) Code ¶

Code gets the status code for the find config rpc interface default response

func (*FindConfigRPCInterfaceDefault) Error ¶

func (*FindConfigRPCInterfaceDefault) GetPayload ¶

type FindConfigRPCInterfaceOK ¶

type FindConfigRPCInterfaceOK struct {
	Payload string
}

FindConfigRPCInterfaceOK handles this case with default header values.

Config value

func NewFindConfigRPCInterfaceOK ¶

func NewFindConfigRPCInterfaceOK() *FindConfigRPCInterfaceOK

NewFindConfigRPCInterfaceOK creates a FindConfigRPCInterfaceOK with default headers values

func (*FindConfigRPCInterfaceOK) GetPayload ¶

func (o *FindConfigRPCInterfaceOK) GetPayload() string

type FindConfigRPCInterfaceParams ¶

type FindConfigRPCInterfaceParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCInterfaceParams contains all the parameters to send to the API endpoint for the find config rpc interface operation typically these are written to a http.Request

func NewFindConfigRPCInterfaceParams ¶

func NewFindConfigRPCInterfaceParams() *FindConfigRPCInterfaceParams

NewFindConfigRPCInterfaceParams creates a new FindConfigRPCInterfaceParams object with the default values initialized.

func NewFindConfigRPCInterfaceParamsWithContext ¶

func NewFindConfigRPCInterfaceParamsWithContext(ctx context.Context) *FindConfigRPCInterfaceParams

NewFindConfigRPCInterfaceParamsWithContext creates a new FindConfigRPCInterfaceParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCInterfaceParamsWithHTTPClient ¶

func NewFindConfigRPCInterfaceParamsWithHTTPClient(client *http.Client) *FindConfigRPCInterfaceParams

NewFindConfigRPCInterfaceParamsWithHTTPClient creates a new FindConfigRPCInterfaceParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCInterfaceParamsWithTimeout ¶

func NewFindConfigRPCInterfaceParamsWithTimeout(timeout time.Duration) *FindConfigRPCInterfaceParams

NewFindConfigRPCInterfaceParamsWithTimeout creates a new FindConfigRPCInterfaceParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCInterfaceParams) SetContext ¶

func (o *FindConfigRPCInterfaceParams) SetContext(ctx context.Context)

SetContext adds the context to the find config rpc interface params

func (*FindConfigRPCInterfaceParams) SetHTTPClient ¶

func (o *FindConfigRPCInterfaceParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc interface params

func (*FindConfigRPCInterfaceParams) SetTimeout ¶

func (o *FindConfigRPCInterfaceParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc interface params

func (*FindConfigRPCInterfaceParams) WithContext ¶

WithContext adds the context to the find config rpc interface params

func (*FindConfigRPCInterfaceParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config rpc interface params

func (*FindConfigRPCInterfaceParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc interface params

func (*FindConfigRPCInterfaceParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCInterfaceReader ¶

type FindConfigRPCInterfaceReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCInterfaceReader is a Reader for the FindConfigRPCInterface structure.

func (*FindConfigRPCInterfaceReader) ReadResponse ¶

func (o *FindConfigRPCInterfaceReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCKeepaliveDefault ¶

type FindConfigRPCKeepaliveDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCKeepaliveDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCKeepaliveDefault ¶

func NewFindConfigRPCKeepaliveDefault(code int) *FindConfigRPCKeepaliveDefault

NewFindConfigRPCKeepaliveDefault creates a FindConfigRPCKeepaliveDefault with default headers values

func (*FindConfigRPCKeepaliveDefault) Code ¶

Code gets the status code for the find config rpc keepalive default response

func (*FindConfigRPCKeepaliveDefault) Error ¶

func (*FindConfigRPCKeepaliveDefault) GetPayload ¶

type FindConfigRPCKeepaliveOK ¶

type FindConfigRPCKeepaliveOK struct {
	Payload bool
}

FindConfigRPCKeepaliveOK handles this case with default header values.

Config value

func NewFindConfigRPCKeepaliveOK ¶

func NewFindConfigRPCKeepaliveOK() *FindConfigRPCKeepaliveOK

NewFindConfigRPCKeepaliveOK creates a FindConfigRPCKeepaliveOK with default headers values

func (*FindConfigRPCKeepaliveOK) GetPayload ¶

func (o *FindConfigRPCKeepaliveOK) GetPayload() bool

type FindConfigRPCKeepaliveParams ¶

type FindConfigRPCKeepaliveParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCKeepaliveParams contains all the parameters to send to the API endpoint for the find config rpc keepalive operation typically these are written to a http.Request

func NewFindConfigRPCKeepaliveParams ¶

func NewFindConfigRPCKeepaliveParams() *FindConfigRPCKeepaliveParams

NewFindConfigRPCKeepaliveParams creates a new FindConfigRPCKeepaliveParams object with the default values initialized.

func NewFindConfigRPCKeepaliveParamsWithContext ¶

func NewFindConfigRPCKeepaliveParamsWithContext(ctx context.Context) *FindConfigRPCKeepaliveParams

NewFindConfigRPCKeepaliveParamsWithContext creates a new FindConfigRPCKeepaliveParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCKeepaliveParamsWithHTTPClient ¶

func NewFindConfigRPCKeepaliveParamsWithHTTPClient(client *http.Client) *FindConfigRPCKeepaliveParams

NewFindConfigRPCKeepaliveParamsWithHTTPClient creates a new FindConfigRPCKeepaliveParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCKeepaliveParamsWithTimeout ¶

func NewFindConfigRPCKeepaliveParamsWithTimeout(timeout time.Duration) *FindConfigRPCKeepaliveParams

NewFindConfigRPCKeepaliveParamsWithTimeout creates a new FindConfigRPCKeepaliveParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCKeepaliveParams) SetContext ¶

func (o *FindConfigRPCKeepaliveParams) SetContext(ctx context.Context)

SetContext adds the context to the find config rpc keepalive params

func (*FindConfigRPCKeepaliveParams) SetHTTPClient ¶

func (o *FindConfigRPCKeepaliveParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc keepalive params

func (*FindConfigRPCKeepaliveParams) SetTimeout ¶

func (o *FindConfigRPCKeepaliveParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc keepalive params

func (*FindConfigRPCKeepaliveParams) WithContext ¶

WithContext adds the context to the find config rpc keepalive params

func (*FindConfigRPCKeepaliveParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config rpc keepalive params

func (*FindConfigRPCKeepaliveParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc keepalive params

func (*FindConfigRPCKeepaliveParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCKeepaliveReader ¶

type FindConfigRPCKeepaliveReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCKeepaliveReader is a Reader for the FindConfigRPCKeepalive structure.

func (*FindConfigRPCKeepaliveReader) ReadResponse ¶

func (o *FindConfigRPCKeepaliveReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCMaxThreadsDefault ¶

type FindConfigRPCMaxThreadsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCMaxThreadsDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCMaxThreadsDefault ¶

func NewFindConfigRPCMaxThreadsDefault(code int) *FindConfigRPCMaxThreadsDefault

NewFindConfigRPCMaxThreadsDefault creates a FindConfigRPCMaxThreadsDefault with default headers values

func (*FindConfigRPCMaxThreadsDefault) Code ¶

Code gets the status code for the find config rpc max threads default response

func (*FindConfigRPCMaxThreadsDefault) Error ¶

func (*FindConfigRPCMaxThreadsDefault) GetPayload ¶

type FindConfigRPCMaxThreadsOK ¶

type FindConfigRPCMaxThreadsOK struct {
	Payload int64
}

FindConfigRPCMaxThreadsOK handles this case with default header values.

Config value

func NewFindConfigRPCMaxThreadsOK ¶

func NewFindConfigRPCMaxThreadsOK() *FindConfigRPCMaxThreadsOK

NewFindConfigRPCMaxThreadsOK creates a FindConfigRPCMaxThreadsOK with default headers values

func (*FindConfigRPCMaxThreadsOK) GetPayload ¶

func (o *FindConfigRPCMaxThreadsOK) GetPayload() int64

type FindConfigRPCMaxThreadsParams ¶

type FindConfigRPCMaxThreadsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCMaxThreadsParams contains all the parameters to send to the API endpoint for the find config rpc max threads operation typically these are written to a http.Request

func NewFindConfigRPCMaxThreadsParams ¶

func NewFindConfigRPCMaxThreadsParams() *FindConfigRPCMaxThreadsParams

NewFindConfigRPCMaxThreadsParams creates a new FindConfigRPCMaxThreadsParams object with the default values initialized.

func NewFindConfigRPCMaxThreadsParamsWithContext ¶

func NewFindConfigRPCMaxThreadsParamsWithContext(ctx context.Context) *FindConfigRPCMaxThreadsParams

NewFindConfigRPCMaxThreadsParamsWithContext creates a new FindConfigRPCMaxThreadsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCMaxThreadsParamsWithHTTPClient ¶

func NewFindConfigRPCMaxThreadsParamsWithHTTPClient(client *http.Client) *FindConfigRPCMaxThreadsParams

NewFindConfigRPCMaxThreadsParamsWithHTTPClient creates a new FindConfigRPCMaxThreadsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCMaxThreadsParamsWithTimeout ¶

func NewFindConfigRPCMaxThreadsParamsWithTimeout(timeout time.Duration) *FindConfigRPCMaxThreadsParams

NewFindConfigRPCMaxThreadsParamsWithTimeout creates a new FindConfigRPCMaxThreadsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCMaxThreadsParams) SetContext ¶

func (o *FindConfigRPCMaxThreadsParams) SetContext(ctx context.Context)

SetContext adds the context to the find config rpc max threads params

func (*FindConfigRPCMaxThreadsParams) SetHTTPClient ¶

func (o *FindConfigRPCMaxThreadsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc max threads params

func (*FindConfigRPCMaxThreadsParams) SetTimeout ¶

func (o *FindConfigRPCMaxThreadsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc max threads params

func (*FindConfigRPCMaxThreadsParams) WithContext ¶

WithContext adds the context to the find config rpc max threads params

func (*FindConfigRPCMaxThreadsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config rpc max threads params

func (*FindConfigRPCMaxThreadsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc max threads params

func (*FindConfigRPCMaxThreadsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCMaxThreadsReader ¶

type FindConfigRPCMaxThreadsReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCMaxThreadsReader is a Reader for the FindConfigRPCMaxThreads structure.

func (*FindConfigRPCMaxThreadsReader) ReadResponse ¶

func (o *FindConfigRPCMaxThreadsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCMinThreadsDefault ¶

type FindConfigRPCMinThreadsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCMinThreadsDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCMinThreadsDefault ¶

func NewFindConfigRPCMinThreadsDefault(code int) *FindConfigRPCMinThreadsDefault

NewFindConfigRPCMinThreadsDefault creates a FindConfigRPCMinThreadsDefault with default headers values

func (*FindConfigRPCMinThreadsDefault) Code ¶

Code gets the status code for the find config rpc min threads default response

func (*FindConfigRPCMinThreadsDefault) Error ¶

func (*FindConfigRPCMinThreadsDefault) GetPayload ¶

type FindConfigRPCMinThreadsOK ¶

type FindConfigRPCMinThreadsOK struct {
	Payload int64
}

FindConfigRPCMinThreadsOK handles this case with default header values.

Config value

func NewFindConfigRPCMinThreadsOK ¶

func NewFindConfigRPCMinThreadsOK() *FindConfigRPCMinThreadsOK

NewFindConfigRPCMinThreadsOK creates a FindConfigRPCMinThreadsOK with default headers values

func (*FindConfigRPCMinThreadsOK) GetPayload ¶

func (o *FindConfigRPCMinThreadsOK) GetPayload() int64

type FindConfigRPCMinThreadsParams ¶

type FindConfigRPCMinThreadsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCMinThreadsParams contains all the parameters to send to the API endpoint for the find config rpc min threads operation typically these are written to a http.Request

func NewFindConfigRPCMinThreadsParams ¶

func NewFindConfigRPCMinThreadsParams() *FindConfigRPCMinThreadsParams

NewFindConfigRPCMinThreadsParams creates a new FindConfigRPCMinThreadsParams object with the default values initialized.

func NewFindConfigRPCMinThreadsParamsWithContext ¶

func NewFindConfigRPCMinThreadsParamsWithContext(ctx context.Context) *FindConfigRPCMinThreadsParams

NewFindConfigRPCMinThreadsParamsWithContext creates a new FindConfigRPCMinThreadsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCMinThreadsParamsWithHTTPClient ¶

func NewFindConfigRPCMinThreadsParamsWithHTTPClient(client *http.Client) *FindConfigRPCMinThreadsParams

NewFindConfigRPCMinThreadsParamsWithHTTPClient creates a new FindConfigRPCMinThreadsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCMinThreadsParamsWithTimeout ¶

func NewFindConfigRPCMinThreadsParamsWithTimeout(timeout time.Duration) *FindConfigRPCMinThreadsParams

NewFindConfigRPCMinThreadsParamsWithTimeout creates a new FindConfigRPCMinThreadsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCMinThreadsParams) SetContext ¶

func (o *FindConfigRPCMinThreadsParams) SetContext(ctx context.Context)

SetContext adds the context to the find config rpc min threads params

func (*FindConfigRPCMinThreadsParams) SetHTTPClient ¶

func (o *FindConfigRPCMinThreadsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc min threads params

func (*FindConfigRPCMinThreadsParams) SetTimeout ¶

func (o *FindConfigRPCMinThreadsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc min threads params

func (*FindConfigRPCMinThreadsParams) WithContext ¶

WithContext adds the context to the find config rpc min threads params

func (*FindConfigRPCMinThreadsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config rpc min threads params

func (*FindConfigRPCMinThreadsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc min threads params

func (*FindConfigRPCMinThreadsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCMinThreadsReader ¶

type FindConfigRPCMinThreadsReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCMinThreadsReader is a Reader for the FindConfigRPCMinThreads structure.

func (*FindConfigRPCMinThreadsReader) ReadResponse ¶

func (o *FindConfigRPCMinThreadsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCPortDefault ¶

type FindConfigRPCPortDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCPortDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCPortDefault ¶

func NewFindConfigRPCPortDefault(code int) *FindConfigRPCPortDefault

NewFindConfigRPCPortDefault creates a FindConfigRPCPortDefault with default headers values

func (*FindConfigRPCPortDefault) Code ¶

func (o *FindConfigRPCPortDefault) Code() int

Code gets the status code for the find config rpc port default response

func (*FindConfigRPCPortDefault) Error ¶

func (o *FindConfigRPCPortDefault) Error() string

func (*FindConfigRPCPortDefault) GetPayload ¶

func (o *FindConfigRPCPortDefault) GetPayload() *models.ErrorModel

type FindConfigRPCPortOK ¶

type FindConfigRPCPortOK struct {
	Payload int64
}

FindConfigRPCPortOK handles this case with default header values.

Config value

func NewFindConfigRPCPortOK ¶

func NewFindConfigRPCPortOK() *FindConfigRPCPortOK

NewFindConfigRPCPortOK creates a FindConfigRPCPortOK with default headers values

func (*FindConfigRPCPortOK) GetPayload ¶

func (o *FindConfigRPCPortOK) GetPayload() int64

type FindConfigRPCPortParams ¶

type FindConfigRPCPortParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCPortParams contains all the parameters to send to the API endpoint for the find config rpc port operation typically these are written to a http.Request

func NewFindConfigRPCPortParams ¶

func NewFindConfigRPCPortParams() *FindConfigRPCPortParams

NewFindConfigRPCPortParams creates a new FindConfigRPCPortParams object with the default values initialized.

func NewFindConfigRPCPortParamsWithContext ¶

func NewFindConfigRPCPortParamsWithContext(ctx context.Context) *FindConfigRPCPortParams

NewFindConfigRPCPortParamsWithContext creates a new FindConfigRPCPortParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCPortParamsWithHTTPClient ¶

func NewFindConfigRPCPortParamsWithHTTPClient(client *http.Client) *FindConfigRPCPortParams

NewFindConfigRPCPortParamsWithHTTPClient creates a new FindConfigRPCPortParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCPortParamsWithTimeout ¶

func NewFindConfigRPCPortParamsWithTimeout(timeout time.Duration) *FindConfigRPCPortParams

NewFindConfigRPCPortParamsWithTimeout creates a new FindConfigRPCPortParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCPortParams) SetContext ¶

func (o *FindConfigRPCPortParams) SetContext(ctx context.Context)

SetContext adds the context to the find config rpc port params

func (*FindConfigRPCPortParams) SetHTTPClient ¶

func (o *FindConfigRPCPortParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc port params

func (*FindConfigRPCPortParams) SetTimeout ¶

func (o *FindConfigRPCPortParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc port params

func (*FindConfigRPCPortParams) WithContext ¶

WithContext adds the context to the find config rpc port params

func (*FindConfigRPCPortParams) WithHTTPClient ¶

func (o *FindConfigRPCPortParams) WithHTTPClient(client *http.Client) *FindConfigRPCPortParams

WithHTTPClient adds the HTTPClient to the find config rpc port params

func (*FindConfigRPCPortParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc port params

func (*FindConfigRPCPortParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCPortReader ¶

type FindConfigRPCPortReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCPortReader is a Reader for the FindConfigRPCPort structure.

func (*FindConfigRPCPortReader) ReadResponse ¶

func (o *FindConfigRPCPortReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCRecvBuffSizeInBytesDefault ¶

type FindConfigRPCRecvBuffSizeInBytesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCRecvBuffSizeInBytesDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCRecvBuffSizeInBytesDefault ¶

func NewFindConfigRPCRecvBuffSizeInBytesDefault(code int) *FindConfigRPCRecvBuffSizeInBytesDefault

NewFindConfigRPCRecvBuffSizeInBytesDefault creates a FindConfigRPCRecvBuffSizeInBytesDefault with default headers values

func (*FindConfigRPCRecvBuffSizeInBytesDefault) Code ¶

Code gets the status code for the find config rpc recv buff size in bytes default response

func (*FindConfigRPCRecvBuffSizeInBytesDefault) Error ¶

func (*FindConfigRPCRecvBuffSizeInBytesDefault) GetPayload ¶

type FindConfigRPCRecvBuffSizeInBytesOK ¶

type FindConfigRPCRecvBuffSizeInBytesOK struct {
	Payload int64
}

FindConfigRPCRecvBuffSizeInBytesOK handles this case with default header values.

Config value

func NewFindConfigRPCRecvBuffSizeInBytesOK ¶

func NewFindConfigRPCRecvBuffSizeInBytesOK() *FindConfigRPCRecvBuffSizeInBytesOK

NewFindConfigRPCRecvBuffSizeInBytesOK creates a FindConfigRPCRecvBuffSizeInBytesOK with default headers values

func (*FindConfigRPCRecvBuffSizeInBytesOK) GetPayload ¶

func (o *FindConfigRPCRecvBuffSizeInBytesOK) GetPayload() int64

type FindConfigRPCRecvBuffSizeInBytesParams ¶

type FindConfigRPCRecvBuffSizeInBytesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCRecvBuffSizeInBytesParams contains all the parameters to send to the API endpoint for the find config rpc recv buff size in bytes operation typically these are written to a http.Request

func NewFindConfigRPCRecvBuffSizeInBytesParams ¶

func NewFindConfigRPCRecvBuffSizeInBytesParams() *FindConfigRPCRecvBuffSizeInBytesParams

NewFindConfigRPCRecvBuffSizeInBytesParams creates a new FindConfigRPCRecvBuffSizeInBytesParams object with the default values initialized.

func NewFindConfigRPCRecvBuffSizeInBytesParamsWithContext ¶

func NewFindConfigRPCRecvBuffSizeInBytesParamsWithContext(ctx context.Context) *FindConfigRPCRecvBuffSizeInBytesParams

NewFindConfigRPCRecvBuffSizeInBytesParamsWithContext creates a new FindConfigRPCRecvBuffSizeInBytesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCRecvBuffSizeInBytesParamsWithHTTPClient ¶

func NewFindConfigRPCRecvBuffSizeInBytesParamsWithHTTPClient(client *http.Client) *FindConfigRPCRecvBuffSizeInBytesParams

NewFindConfigRPCRecvBuffSizeInBytesParamsWithHTTPClient creates a new FindConfigRPCRecvBuffSizeInBytesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCRecvBuffSizeInBytesParamsWithTimeout ¶

func NewFindConfigRPCRecvBuffSizeInBytesParamsWithTimeout(timeout time.Duration) *FindConfigRPCRecvBuffSizeInBytesParams

NewFindConfigRPCRecvBuffSizeInBytesParamsWithTimeout creates a new FindConfigRPCRecvBuffSizeInBytesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCRecvBuffSizeInBytesParams) SetContext ¶

SetContext adds the context to the find config rpc recv buff size in bytes params

func (*FindConfigRPCRecvBuffSizeInBytesParams) SetHTTPClient ¶

func (o *FindConfigRPCRecvBuffSizeInBytesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc recv buff size in bytes params

func (*FindConfigRPCRecvBuffSizeInBytesParams) SetTimeout ¶

func (o *FindConfigRPCRecvBuffSizeInBytesParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc recv buff size in bytes params

func (*FindConfigRPCRecvBuffSizeInBytesParams) WithContext ¶

WithContext adds the context to the find config rpc recv buff size in bytes params

func (*FindConfigRPCRecvBuffSizeInBytesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config rpc recv buff size in bytes params

func (*FindConfigRPCRecvBuffSizeInBytesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc recv buff size in bytes params

func (*FindConfigRPCRecvBuffSizeInBytesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCRecvBuffSizeInBytesReader ¶

type FindConfigRPCRecvBuffSizeInBytesReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCRecvBuffSizeInBytesReader is a Reader for the FindConfigRPCRecvBuffSizeInBytes structure.

func (*FindConfigRPCRecvBuffSizeInBytesReader) ReadResponse ¶

func (o *FindConfigRPCRecvBuffSizeInBytesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCSendBuffSizeInBytesDefault ¶

type FindConfigRPCSendBuffSizeInBytesDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCSendBuffSizeInBytesDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCSendBuffSizeInBytesDefault ¶

func NewFindConfigRPCSendBuffSizeInBytesDefault(code int) *FindConfigRPCSendBuffSizeInBytesDefault

NewFindConfigRPCSendBuffSizeInBytesDefault creates a FindConfigRPCSendBuffSizeInBytesDefault with default headers values

func (*FindConfigRPCSendBuffSizeInBytesDefault) Code ¶

Code gets the status code for the find config rpc send buff size in bytes default response

func (*FindConfigRPCSendBuffSizeInBytesDefault) Error ¶

func (*FindConfigRPCSendBuffSizeInBytesDefault) GetPayload ¶

type FindConfigRPCSendBuffSizeInBytesOK ¶

type FindConfigRPCSendBuffSizeInBytesOK struct {
	Payload int64
}

FindConfigRPCSendBuffSizeInBytesOK handles this case with default header values.

Config value

func NewFindConfigRPCSendBuffSizeInBytesOK ¶

func NewFindConfigRPCSendBuffSizeInBytesOK() *FindConfigRPCSendBuffSizeInBytesOK

NewFindConfigRPCSendBuffSizeInBytesOK creates a FindConfigRPCSendBuffSizeInBytesOK with default headers values

func (*FindConfigRPCSendBuffSizeInBytesOK) GetPayload ¶

func (o *FindConfigRPCSendBuffSizeInBytesOK) GetPayload() int64

type FindConfigRPCSendBuffSizeInBytesParams ¶

type FindConfigRPCSendBuffSizeInBytesParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCSendBuffSizeInBytesParams contains all the parameters to send to the API endpoint for the find config rpc send buff size in bytes operation typically these are written to a http.Request

func NewFindConfigRPCSendBuffSizeInBytesParams ¶

func NewFindConfigRPCSendBuffSizeInBytesParams() *FindConfigRPCSendBuffSizeInBytesParams

NewFindConfigRPCSendBuffSizeInBytesParams creates a new FindConfigRPCSendBuffSizeInBytesParams object with the default values initialized.

func NewFindConfigRPCSendBuffSizeInBytesParamsWithContext ¶

func NewFindConfigRPCSendBuffSizeInBytesParamsWithContext(ctx context.Context) *FindConfigRPCSendBuffSizeInBytesParams

NewFindConfigRPCSendBuffSizeInBytesParamsWithContext creates a new FindConfigRPCSendBuffSizeInBytesParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCSendBuffSizeInBytesParamsWithHTTPClient ¶

func NewFindConfigRPCSendBuffSizeInBytesParamsWithHTTPClient(client *http.Client) *FindConfigRPCSendBuffSizeInBytesParams

NewFindConfigRPCSendBuffSizeInBytesParamsWithHTTPClient creates a new FindConfigRPCSendBuffSizeInBytesParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCSendBuffSizeInBytesParamsWithTimeout ¶

func NewFindConfigRPCSendBuffSizeInBytesParamsWithTimeout(timeout time.Duration) *FindConfigRPCSendBuffSizeInBytesParams

NewFindConfigRPCSendBuffSizeInBytesParamsWithTimeout creates a new FindConfigRPCSendBuffSizeInBytesParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCSendBuffSizeInBytesParams) SetContext ¶

SetContext adds the context to the find config rpc send buff size in bytes params

func (*FindConfigRPCSendBuffSizeInBytesParams) SetHTTPClient ¶

func (o *FindConfigRPCSendBuffSizeInBytesParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc send buff size in bytes params

func (*FindConfigRPCSendBuffSizeInBytesParams) SetTimeout ¶

func (o *FindConfigRPCSendBuffSizeInBytesParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc send buff size in bytes params

func (*FindConfigRPCSendBuffSizeInBytesParams) WithContext ¶

WithContext adds the context to the find config rpc send buff size in bytes params

func (*FindConfigRPCSendBuffSizeInBytesParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config rpc send buff size in bytes params

func (*FindConfigRPCSendBuffSizeInBytesParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc send buff size in bytes params

func (*FindConfigRPCSendBuffSizeInBytesParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCSendBuffSizeInBytesReader ¶

type FindConfigRPCSendBuffSizeInBytesReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCSendBuffSizeInBytesReader is a Reader for the FindConfigRPCSendBuffSizeInBytes structure.

func (*FindConfigRPCSendBuffSizeInBytesReader) ReadResponse ¶

func (o *FindConfigRPCSendBuffSizeInBytesReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRPCServerTypeDefault ¶

type FindConfigRPCServerTypeDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRPCServerTypeDefault handles this case with default header values.

unexpected error

func NewFindConfigRPCServerTypeDefault ¶

func NewFindConfigRPCServerTypeDefault(code int) *FindConfigRPCServerTypeDefault

NewFindConfigRPCServerTypeDefault creates a FindConfigRPCServerTypeDefault with default headers values

func (*FindConfigRPCServerTypeDefault) Code ¶

Code gets the status code for the find config rpc server type default response

func (*FindConfigRPCServerTypeDefault) Error ¶

func (*FindConfigRPCServerTypeDefault) GetPayload ¶

type FindConfigRPCServerTypeOK ¶

type FindConfigRPCServerTypeOK struct {
	Payload string
}

FindConfigRPCServerTypeOK handles this case with default header values.

Config value

func NewFindConfigRPCServerTypeOK ¶

func NewFindConfigRPCServerTypeOK() *FindConfigRPCServerTypeOK

NewFindConfigRPCServerTypeOK creates a FindConfigRPCServerTypeOK with default headers values

func (*FindConfigRPCServerTypeOK) GetPayload ¶

func (o *FindConfigRPCServerTypeOK) GetPayload() string

type FindConfigRPCServerTypeParams ¶

type FindConfigRPCServerTypeParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRPCServerTypeParams contains all the parameters to send to the API endpoint for the find config rpc server type operation typically these are written to a http.Request

func NewFindConfigRPCServerTypeParams ¶

func NewFindConfigRPCServerTypeParams() *FindConfigRPCServerTypeParams

NewFindConfigRPCServerTypeParams creates a new FindConfigRPCServerTypeParams object with the default values initialized.

func NewFindConfigRPCServerTypeParamsWithContext ¶

func NewFindConfigRPCServerTypeParamsWithContext(ctx context.Context) *FindConfigRPCServerTypeParams

NewFindConfigRPCServerTypeParamsWithContext creates a new FindConfigRPCServerTypeParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRPCServerTypeParamsWithHTTPClient ¶

func NewFindConfigRPCServerTypeParamsWithHTTPClient(client *http.Client) *FindConfigRPCServerTypeParams

NewFindConfigRPCServerTypeParamsWithHTTPClient creates a new FindConfigRPCServerTypeParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRPCServerTypeParamsWithTimeout ¶

func NewFindConfigRPCServerTypeParamsWithTimeout(timeout time.Duration) *FindConfigRPCServerTypeParams

NewFindConfigRPCServerTypeParamsWithTimeout creates a new FindConfigRPCServerTypeParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRPCServerTypeParams) SetContext ¶

func (o *FindConfigRPCServerTypeParams) SetContext(ctx context.Context)

SetContext adds the context to the find config rpc server type params

func (*FindConfigRPCServerTypeParams) SetHTTPClient ¶

func (o *FindConfigRPCServerTypeParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config rpc server type params

func (*FindConfigRPCServerTypeParams) SetTimeout ¶

func (o *FindConfigRPCServerTypeParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config rpc server type params

func (*FindConfigRPCServerTypeParams) WithContext ¶

WithContext adds the context to the find config rpc server type params

func (*FindConfigRPCServerTypeParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config rpc server type params

func (*FindConfigRPCServerTypeParams) WithTimeout ¶

WithTimeout adds the timeout to the find config rpc server type params

func (*FindConfigRPCServerTypeParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRPCServerTypeReader ¶

type FindConfigRPCServerTypeReader struct {
	// contains filtered or unexported fields
}

FindConfigRPCServerTypeReader is a Reader for the FindConfigRPCServerType structure.

func (*FindConfigRPCServerTypeReader) ReadResponse ¶

func (o *FindConfigRPCServerTypeReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRangeRequestTimeoutInMsDefault ¶

type FindConfigRangeRequestTimeoutInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRangeRequestTimeoutInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigRangeRequestTimeoutInMsDefault ¶

func NewFindConfigRangeRequestTimeoutInMsDefault(code int) *FindConfigRangeRequestTimeoutInMsDefault

NewFindConfigRangeRequestTimeoutInMsDefault creates a FindConfigRangeRequestTimeoutInMsDefault with default headers values

func (*FindConfigRangeRequestTimeoutInMsDefault) Code ¶

Code gets the status code for the find config range request timeout in ms default response

func (*FindConfigRangeRequestTimeoutInMsDefault) Error ¶

func (*FindConfigRangeRequestTimeoutInMsDefault) GetPayload ¶

type FindConfigRangeRequestTimeoutInMsOK ¶

type FindConfigRangeRequestTimeoutInMsOK struct {
	Payload int64
}

FindConfigRangeRequestTimeoutInMsOK handles this case with default header values.

Config value

func NewFindConfigRangeRequestTimeoutInMsOK ¶

func NewFindConfigRangeRequestTimeoutInMsOK() *FindConfigRangeRequestTimeoutInMsOK

NewFindConfigRangeRequestTimeoutInMsOK creates a FindConfigRangeRequestTimeoutInMsOK with default headers values

func (*FindConfigRangeRequestTimeoutInMsOK) GetPayload ¶

type FindConfigRangeRequestTimeoutInMsParams ¶

type FindConfigRangeRequestTimeoutInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRangeRequestTimeoutInMsParams contains all the parameters to send to the API endpoint for the find config range request timeout in ms operation typically these are written to a http.Request

func NewFindConfigRangeRequestTimeoutInMsParams ¶

func NewFindConfigRangeRequestTimeoutInMsParams() *FindConfigRangeRequestTimeoutInMsParams

NewFindConfigRangeRequestTimeoutInMsParams creates a new FindConfigRangeRequestTimeoutInMsParams object with the default values initialized.

func NewFindConfigRangeRequestTimeoutInMsParamsWithContext ¶

func NewFindConfigRangeRequestTimeoutInMsParamsWithContext(ctx context.Context) *FindConfigRangeRequestTimeoutInMsParams

NewFindConfigRangeRequestTimeoutInMsParamsWithContext creates a new FindConfigRangeRequestTimeoutInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRangeRequestTimeoutInMsParamsWithHTTPClient ¶

func NewFindConfigRangeRequestTimeoutInMsParamsWithHTTPClient(client *http.Client) *FindConfigRangeRequestTimeoutInMsParams

NewFindConfigRangeRequestTimeoutInMsParamsWithHTTPClient creates a new FindConfigRangeRequestTimeoutInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRangeRequestTimeoutInMsParamsWithTimeout ¶

func NewFindConfigRangeRequestTimeoutInMsParamsWithTimeout(timeout time.Duration) *FindConfigRangeRequestTimeoutInMsParams

NewFindConfigRangeRequestTimeoutInMsParamsWithTimeout creates a new FindConfigRangeRequestTimeoutInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRangeRequestTimeoutInMsParams) SetContext ¶

SetContext adds the context to the find config range request timeout in ms params

func (*FindConfigRangeRequestTimeoutInMsParams) SetHTTPClient ¶

func (o *FindConfigRangeRequestTimeoutInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config range request timeout in ms params

func (*FindConfigRangeRequestTimeoutInMsParams) SetTimeout ¶

func (o *FindConfigRangeRequestTimeoutInMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config range request timeout in ms params

func (*FindConfigRangeRequestTimeoutInMsParams) WithContext ¶

WithContext adds the context to the find config range request timeout in ms params

func (*FindConfigRangeRequestTimeoutInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config range request timeout in ms params

func (*FindConfigRangeRequestTimeoutInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config range request timeout in ms params

func (*FindConfigRangeRequestTimeoutInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRangeRequestTimeoutInMsReader ¶

type FindConfigRangeRequestTimeoutInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigRangeRequestTimeoutInMsReader is a Reader for the FindConfigRangeRequestTimeoutInMs structure.

func (*FindConfigRangeRequestTimeoutInMsReader) ReadResponse ¶

func (o *FindConfigRangeRequestTimeoutInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigReadRequestTimeoutInMsDefault ¶

type FindConfigReadRequestTimeoutInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigReadRequestTimeoutInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigReadRequestTimeoutInMsDefault ¶

func NewFindConfigReadRequestTimeoutInMsDefault(code int) *FindConfigReadRequestTimeoutInMsDefault

NewFindConfigReadRequestTimeoutInMsDefault creates a FindConfigReadRequestTimeoutInMsDefault with default headers values

func (*FindConfigReadRequestTimeoutInMsDefault) Code ¶

Code gets the status code for the find config read request timeout in ms default response

func (*FindConfigReadRequestTimeoutInMsDefault) Error ¶

func (*FindConfigReadRequestTimeoutInMsDefault) GetPayload ¶

type FindConfigReadRequestTimeoutInMsOK ¶

type FindConfigReadRequestTimeoutInMsOK struct {
	Payload int64
}

FindConfigReadRequestTimeoutInMsOK handles this case with default header values.

Config value

func NewFindConfigReadRequestTimeoutInMsOK ¶

func NewFindConfigReadRequestTimeoutInMsOK() *FindConfigReadRequestTimeoutInMsOK

NewFindConfigReadRequestTimeoutInMsOK creates a FindConfigReadRequestTimeoutInMsOK with default headers values

func (*FindConfigReadRequestTimeoutInMsOK) GetPayload ¶

func (o *FindConfigReadRequestTimeoutInMsOK) GetPayload() int64

type FindConfigReadRequestTimeoutInMsParams ¶

type FindConfigReadRequestTimeoutInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigReadRequestTimeoutInMsParams contains all the parameters to send to the API endpoint for the find config read request timeout in ms operation typically these are written to a http.Request

func NewFindConfigReadRequestTimeoutInMsParams ¶

func NewFindConfigReadRequestTimeoutInMsParams() *FindConfigReadRequestTimeoutInMsParams

NewFindConfigReadRequestTimeoutInMsParams creates a new FindConfigReadRequestTimeoutInMsParams object with the default values initialized.

func NewFindConfigReadRequestTimeoutInMsParamsWithContext ¶

func NewFindConfigReadRequestTimeoutInMsParamsWithContext(ctx context.Context) *FindConfigReadRequestTimeoutInMsParams

NewFindConfigReadRequestTimeoutInMsParamsWithContext creates a new FindConfigReadRequestTimeoutInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigReadRequestTimeoutInMsParamsWithHTTPClient ¶

func NewFindConfigReadRequestTimeoutInMsParamsWithHTTPClient(client *http.Client) *FindConfigReadRequestTimeoutInMsParams

NewFindConfigReadRequestTimeoutInMsParamsWithHTTPClient creates a new FindConfigReadRequestTimeoutInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigReadRequestTimeoutInMsParamsWithTimeout ¶

func NewFindConfigReadRequestTimeoutInMsParamsWithTimeout(timeout time.Duration) *FindConfigReadRequestTimeoutInMsParams

NewFindConfigReadRequestTimeoutInMsParamsWithTimeout creates a new FindConfigReadRequestTimeoutInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigReadRequestTimeoutInMsParams) SetContext ¶

SetContext adds the context to the find config read request timeout in ms params

func (*FindConfigReadRequestTimeoutInMsParams) SetHTTPClient ¶

func (o *FindConfigReadRequestTimeoutInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config read request timeout in ms params

func (*FindConfigReadRequestTimeoutInMsParams) SetTimeout ¶

func (o *FindConfigReadRequestTimeoutInMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config read request timeout in ms params

func (*FindConfigReadRequestTimeoutInMsParams) WithContext ¶

WithContext adds the context to the find config read request timeout in ms params

func (*FindConfigReadRequestTimeoutInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config read request timeout in ms params

func (*FindConfigReadRequestTimeoutInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config read request timeout in ms params

func (*FindConfigReadRequestTimeoutInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigReadRequestTimeoutInMsReader ¶

type FindConfigReadRequestTimeoutInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigReadRequestTimeoutInMsReader is a Reader for the FindConfigReadRequestTimeoutInMs structure.

func (*FindConfigReadRequestTimeoutInMsReader) ReadResponse ¶

func (o *FindConfigReadRequestTimeoutInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigReduceCacheCapacityToDefault ¶

type FindConfigReduceCacheCapacityToDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigReduceCacheCapacityToDefault handles this case with default header values.

unexpected error

func NewFindConfigReduceCacheCapacityToDefault ¶

func NewFindConfigReduceCacheCapacityToDefault(code int) *FindConfigReduceCacheCapacityToDefault

NewFindConfigReduceCacheCapacityToDefault creates a FindConfigReduceCacheCapacityToDefault with default headers values

func (*FindConfigReduceCacheCapacityToDefault) Code ¶

Code gets the status code for the find config reduce cache capacity to default response

func (*FindConfigReduceCacheCapacityToDefault) Error ¶

func (*FindConfigReduceCacheCapacityToDefault) GetPayload ¶

type FindConfigReduceCacheCapacityToOK ¶

type FindConfigReduceCacheCapacityToOK struct {
	Payload float64
}

FindConfigReduceCacheCapacityToOK handles this case with default header values.

Config value

func NewFindConfigReduceCacheCapacityToOK ¶

func NewFindConfigReduceCacheCapacityToOK() *FindConfigReduceCacheCapacityToOK

NewFindConfigReduceCacheCapacityToOK creates a FindConfigReduceCacheCapacityToOK with default headers values

func (*FindConfigReduceCacheCapacityToOK) GetPayload ¶

type FindConfigReduceCacheCapacityToParams ¶

type FindConfigReduceCacheCapacityToParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigReduceCacheCapacityToParams contains all the parameters to send to the API endpoint for the find config reduce cache capacity to operation typically these are written to a http.Request

func NewFindConfigReduceCacheCapacityToParams ¶

func NewFindConfigReduceCacheCapacityToParams() *FindConfigReduceCacheCapacityToParams

NewFindConfigReduceCacheCapacityToParams creates a new FindConfigReduceCacheCapacityToParams object with the default values initialized.

func NewFindConfigReduceCacheCapacityToParamsWithContext ¶

func NewFindConfigReduceCacheCapacityToParamsWithContext(ctx context.Context) *FindConfigReduceCacheCapacityToParams

NewFindConfigReduceCacheCapacityToParamsWithContext creates a new FindConfigReduceCacheCapacityToParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigReduceCacheCapacityToParamsWithHTTPClient ¶

func NewFindConfigReduceCacheCapacityToParamsWithHTTPClient(client *http.Client) *FindConfigReduceCacheCapacityToParams

NewFindConfigReduceCacheCapacityToParamsWithHTTPClient creates a new FindConfigReduceCacheCapacityToParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigReduceCacheCapacityToParamsWithTimeout ¶

func NewFindConfigReduceCacheCapacityToParamsWithTimeout(timeout time.Duration) *FindConfigReduceCacheCapacityToParams

NewFindConfigReduceCacheCapacityToParamsWithTimeout creates a new FindConfigReduceCacheCapacityToParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigReduceCacheCapacityToParams) SetContext ¶

SetContext adds the context to the find config reduce cache capacity to params

func (*FindConfigReduceCacheCapacityToParams) SetHTTPClient ¶

func (o *FindConfigReduceCacheCapacityToParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config reduce cache capacity to params

func (*FindConfigReduceCacheCapacityToParams) SetTimeout ¶

func (o *FindConfigReduceCacheCapacityToParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config reduce cache capacity to params

func (*FindConfigReduceCacheCapacityToParams) WithContext ¶

WithContext adds the context to the find config reduce cache capacity to params

func (*FindConfigReduceCacheCapacityToParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config reduce cache capacity to params

func (*FindConfigReduceCacheCapacityToParams) WithTimeout ¶

WithTimeout adds the timeout to the find config reduce cache capacity to params

func (*FindConfigReduceCacheCapacityToParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigReduceCacheCapacityToReader ¶

type FindConfigReduceCacheCapacityToReader struct {
	// contains filtered or unexported fields
}

FindConfigReduceCacheCapacityToReader is a Reader for the FindConfigReduceCacheCapacityTo structure.

func (*FindConfigReduceCacheCapacityToReader) ReadResponse ¶

func (o *FindConfigReduceCacheCapacityToReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigReduceCacheSizesAtDefault ¶

type FindConfigReduceCacheSizesAtDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigReduceCacheSizesAtDefault handles this case with default header values.

unexpected error

func NewFindConfigReduceCacheSizesAtDefault ¶

func NewFindConfigReduceCacheSizesAtDefault(code int) *FindConfigReduceCacheSizesAtDefault

NewFindConfigReduceCacheSizesAtDefault creates a FindConfigReduceCacheSizesAtDefault with default headers values

func (*FindConfigReduceCacheSizesAtDefault) Code ¶

Code gets the status code for the find config reduce cache sizes at default response

func (*FindConfigReduceCacheSizesAtDefault) Error ¶

func (*FindConfigReduceCacheSizesAtDefault) GetPayload ¶

type FindConfigReduceCacheSizesAtOK ¶

type FindConfigReduceCacheSizesAtOK struct {
	Payload float64
}

FindConfigReduceCacheSizesAtOK handles this case with default header values.

Config value

func NewFindConfigReduceCacheSizesAtOK ¶

func NewFindConfigReduceCacheSizesAtOK() *FindConfigReduceCacheSizesAtOK

NewFindConfigReduceCacheSizesAtOK creates a FindConfigReduceCacheSizesAtOK with default headers values

func (*FindConfigReduceCacheSizesAtOK) GetPayload ¶

func (o *FindConfigReduceCacheSizesAtOK) GetPayload() float64

type FindConfigReduceCacheSizesAtParams ¶

type FindConfigReduceCacheSizesAtParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigReduceCacheSizesAtParams contains all the parameters to send to the API endpoint for the find config reduce cache sizes at operation typically these are written to a http.Request

func NewFindConfigReduceCacheSizesAtParams ¶

func NewFindConfigReduceCacheSizesAtParams() *FindConfigReduceCacheSizesAtParams

NewFindConfigReduceCacheSizesAtParams creates a new FindConfigReduceCacheSizesAtParams object with the default values initialized.

func NewFindConfigReduceCacheSizesAtParamsWithContext ¶

func NewFindConfigReduceCacheSizesAtParamsWithContext(ctx context.Context) *FindConfigReduceCacheSizesAtParams

NewFindConfigReduceCacheSizesAtParamsWithContext creates a new FindConfigReduceCacheSizesAtParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigReduceCacheSizesAtParamsWithHTTPClient ¶

func NewFindConfigReduceCacheSizesAtParamsWithHTTPClient(client *http.Client) *FindConfigReduceCacheSizesAtParams

NewFindConfigReduceCacheSizesAtParamsWithHTTPClient creates a new FindConfigReduceCacheSizesAtParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigReduceCacheSizesAtParamsWithTimeout ¶

func NewFindConfigReduceCacheSizesAtParamsWithTimeout(timeout time.Duration) *FindConfigReduceCacheSizesAtParams

NewFindConfigReduceCacheSizesAtParamsWithTimeout creates a new FindConfigReduceCacheSizesAtParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigReduceCacheSizesAtParams) SetContext ¶

SetContext adds the context to the find config reduce cache sizes at params

func (*FindConfigReduceCacheSizesAtParams) SetHTTPClient ¶

func (o *FindConfigReduceCacheSizesAtParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config reduce cache sizes at params

func (*FindConfigReduceCacheSizesAtParams) SetTimeout ¶

func (o *FindConfigReduceCacheSizesAtParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config reduce cache sizes at params

func (*FindConfigReduceCacheSizesAtParams) WithContext ¶

WithContext adds the context to the find config reduce cache sizes at params

func (*FindConfigReduceCacheSizesAtParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config reduce cache sizes at params

func (*FindConfigReduceCacheSizesAtParams) WithTimeout ¶

WithTimeout adds the timeout to the find config reduce cache sizes at params

func (*FindConfigReduceCacheSizesAtParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigReduceCacheSizesAtReader ¶

type FindConfigReduceCacheSizesAtReader struct {
	// contains filtered or unexported fields
}

FindConfigReduceCacheSizesAtReader is a Reader for the FindConfigReduceCacheSizesAt structure.

func (*FindConfigReduceCacheSizesAtReader) ReadResponse ¶

func (o *FindConfigReduceCacheSizesAtReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigReplaceAddressDefault ¶

type FindConfigReplaceAddressDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigReplaceAddressDefault handles this case with default header values.

unexpected error

func NewFindConfigReplaceAddressDefault ¶

func NewFindConfigReplaceAddressDefault(code int) *FindConfigReplaceAddressDefault

NewFindConfigReplaceAddressDefault creates a FindConfigReplaceAddressDefault with default headers values

func (*FindConfigReplaceAddressDefault) Code ¶

Code gets the status code for the find config replace address default response

func (*FindConfigReplaceAddressDefault) Error ¶

func (*FindConfigReplaceAddressDefault) GetPayload ¶

type FindConfigReplaceAddressFirstBootDefault ¶

type FindConfigReplaceAddressFirstBootDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigReplaceAddressFirstBootDefault handles this case with default header values.

unexpected error

func NewFindConfigReplaceAddressFirstBootDefault ¶

func NewFindConfigReplaceAddressFirstBootDefault(code int) *FindConfigReplaceAddressFirstBootDefault

NewFindConfigReplaceAddressFirstBootDefault creates a FindConfigReplaceAddressFirstBootDefault with default headers values

func (*FindConfigReplaceAddressFirstBootDefault) Code ¶

Code gets the status code for the find config replace address first boot default response

func (*FindConfigReplaceAddressFirstBootDefault) Error ¶

func (*FindConfigReplaceAddressFirstBootDefault) GetPayload ¶

type FindConfigReplaceAddressFirstBootOK ¶

type FindConfigReplaceAddressFirstBootOK struct {
	Payload string
}

FindConfigReplaceAddressFirstBootOK handles this case with default header values.

Config value

func NewFindConfigReplaceAddressFirstBootOK ¶

func NewFindConfigReplaceAddressFirstBootOK() *FindConfigReplaceAddressFirstBootOK

NewFindConfigReplaceAddressFirstBootOK creates a FindConfigReplaceAddressFirstBootOK with default headers values

func (*FindConfigReplaceAddressFirstBootOK) GetPayload ¶

type FindConfigReplaceAddressFirstBootParams ¶

type FindConfigReplaceAddressFirstBootParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigReplaceAddressFirstBootParams contains all the parameters to send to the API endpoint for the find config replace address first boot operation typically these are written to a http.Request

func NewFindConfigReplaceAddressFirstBootParams ¶

func NewFindConfigReplaceAddressFirstBootParams() *FindConfigReplaceAddressFirstBootParams

NewFindConfigReplaceAddressFirstBootParams creates a new FindConfigReplaceAddressFirstBootParams object with the default values initialized.

func NewFindConfigReplaceAddressFirstBootParamsWithContext ¶

func NewFindConfigReplaceAddressFirstBootParamsWithContext(ctx context.Context) *FindConfigReplaceAddressFirstBootParams

NewFindConfigReplaceAddressFirstBootParamsWithContext creates a new FindConfigReplaceAddressFirstBootParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigReplaceAddressFirstBootParamsWithHTTPClient ¶

func NewFindConfigReplaceAddressFirstBootParamsWithHTTPClient(client *http.Client) *FindConfigReplaceAddressFirstBootParams

NewFindConfigReplaceAddressFirstBootParamsWithHTTPClient creates a new FindConfigReplaceAddressFirstBootParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigReplaceAddressFirstBootParamsWithTimeout ¶

func NewFindConfigReplaceAddressFirstBootParamsWithTimeout(timeout time.Duration) *FindConfigReplaceAddressFirstBootParams

NewFindConfigReplaceAddressFirstBootParamsWithTimeout creates a new FindConfigReplaceAddressFirstBootParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigReplaceAddressFirstBootParams) SetContext ¶

SetContext adds the context to the find config replace address first boot params

func (*FindConfigReplaceAddressFirstBootParams) SetHTTPClient ¶

func (o *FindConfigReplaceAddressFirstBootParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config replace address first boot params

func (*FindConfigReplaceAddressFirstBootParams) SetTimeout ¶

func (o *FindConfigReplaceAddressFirstBootParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config replace address first boot params

func (*FindConfigReplaceAddressFirstBootParams) WithContext ¶

WithContext adds the context to the find config replace address first boot params

func (*FindConfigReplaceAddressFirstBootParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config replace address first boot params

func (*FindConfigReplaceAddressFirstBootParams) WithTimeout ¶

WithTimeout adds the timeout to the find config replace address first boot params

func (*FindConfigReplaceAddressFirstBootParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigReplaceAddressFirstBootReader ¶

type FindConfigReplaceAddressFirstBootReader struct {
	// contains filtered or unexported fields
}

FindConfigReplaceAddressFirstBootReader is a Reader for the FindConfigReplaceAddressFirstBoot structure.

func (*FindConfigReplaceAddressFirstBootReader) ReadResponse ¶

func (o *FindConfigReplaceAddressFirstBootReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigReplaceAddressOK ¶

type FindConfigReplaceAddressOK struct {
	Payload string
}

FindConfigReplaceAddressOK handles this case with default header values.

Config value

func NewFindConfigReplaceAddressOK ¶

func NewFindConfigReplaceAddressOK() *FindConfigReplaceAddressOK

NewFindConfigReplaceAddressOK creates a FindConfigReplaceAddressOK with default headers values

func (*FindConfigReplaceAddressOK) GetPayload ¶

func (o *FindConfigReplaceAddressOK) GetPayload() string

type FindConfigReplaceAddressParams ¶

type FindConfigReplaceAddressParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigReplaceAddressParams contains all the parameters to send to the API endpoint for the find config replace address operation typically these are written to a http.Request

func NewFindConfigReplaceAddressParams ¶

func NewFindConfigReplaceAddressParams() *FindConfigReplaceAddressParams

NewFindConfigReplaceAddressParams creates a new FindConfigReplaceAddressParams object with the default values initialized.

func NewFindConfigReplaceAddressParamsWithContext ¶

func NewFindConfigReplaceAddressParamsWithContext(ctx context.Context) *FindConfigReplaceAddressParams

NewFindConfigReplaceAddressParamsWithContext creates a new FindConfigReplaceAddressParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigReplaceAddressParamsWithHTTPClient ¶

func NewFindConfigReplaceAddressParamsWithHTTPClient(client *http.Client) *FindConfigReplaceAddressParams

NewFindConfigReplaceAddressParamsWithHTTPClient creates a new FindConfigReplaceAddressParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigReplaceAddressParamsWithTimeout ¶

func NewFindConfigReplaceAddressParamsWithTimeout(timeout time.Duration) *FindConfigReplaceAddressParams

NewFindConfigReplaceAddressParamsWithTimeout creates a new FindConfigReplaceAddressParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigReplaceAddressParams) SetContext ¶

func (o *FindConfigReplaceAddressParams) SetContext(ctx context.Context)

SetContext adds the context to the find config replace address params

func (*FindConfigReplaceAddressParams) SetHTTPClient ¶

func (o *FindConfigReplaceAddressParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config replace address params

func (*FindConfigReplaceAddressParams) SetTimeout ¶

func (o *FindConfigReplaceAddressParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config replace address params

func (*FindConfigReplaceAddressParams) WithContext ¶

WithContext adds the context to the find config replace address params

func (*FindConfigReplaceAddressParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config replace address params

func (*FindConfigReplaceAddressParams) WithTimeout ¶

WithTimeout adds the timeout to the find config replace address params

func (*FindConfigReplaceAddressParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigReplaceAddressReader ¶

type FindConfigReplaceAddressReader struct {
	// contains filtered or unexported fields
}

FindConfigReplaceAddressReader is a Reader for the FindConfigReplaceAddress structure.

func (*FindConfigReplaceAddressReader) ReadResponse ¶

func (o *FindConfigReplaceAddressReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigReplaceNodeDefault ¶

type FindConfigReplaceNodeDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigReplaceNodeDefault handles this case with default header values.

unexpected error

func NewFindConfigReplaceNodeDefault ¶

func NewFindConfigReplaceNodeDefault(code int) *FindConfigReplaceNodeDefault

NewFindConfigReplaceNodeDefault creates a FindConfigReplaceNodeDefault with default headers values

func (*FindConfigReplaceNodeDefault) Code ¶

Code gets the status code for the find config replace node default response

func (*FindConfigReplaceNodeDefault) Error ¶

func (*FindConfigReplaceNodeDefault) GetPayload ¶

type FindConfigReplaceNodeOK ¶

type FindConfigReplaceNodeOK struct {
	Payload string
}

FindConfigReplaceNodeOK handles this case with default header values.

Config value

func NewFindConfigReplaceNodeOK ¶

func NewFindConfigReplaceNodeOK() *FindConfigReplaceNodeOK

NewFindConfigReplaceNodeOK creates a FindConfigReplaceNodeOK with default headers values

func (*FindConfigReplaceNodeOK) GetPayload ¶

func (o *FindConfigReplaceNodeOK) GetPayload() string

type FindConfigReplaceNodeParams ¶

type FindConfigReplaceNodeParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigReplaceNodeParams contains all the parameters to send to the API endpoint for the find config replace node operation typically these are written to a http.Request

func NewFindConfigReplaceNodeParams ¶

func NewFindConfigReplaceNodeParams() *FindConfigReplaceNodeParams

NewFindConfigReplaceNodeParams creates a new FindConfigReplaceNodeParams object with the default values initialized.

func NewFindConfigReplaceNodeParamsWithContext ¶

func NewFindConfigReplaceNodeParamsWithContext(ctx context.Context) *FindConfigReplaceNodeParams

NewFindConfigReplaceNodeParamsWithContext creates a new FindConfigReplaceNodeParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigReplaceNodeParamsWithHTTPClient ¶

func NewFindConfigReplaceNodeParamsWithHTTPClient(client *http.Client) *FindConfigReplaceNodeParams

NewFindConfigReplaceNodeParamsWithHTTPClient creates a new FindConfigReplaceNodeParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigReplaceNodeParamsWithTimeout ¶

func NewFindConfigReplaceNodeParamsWithTimeout(timeout time.Duration) *FindConfigReplaceNodeParams

NewFindConfigReplaceNodeParamsWithTimeout creates a new FindConfigReplaceNodeParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigReplaceNodeParams) SetContext ¶

func (o *FindConfigReplaceNodeParams) SetContext(ctx context.Context)

SetContext adds the context to the find config replace node params

func (*FindConfigReplaceNodeParams) SetHTTPClient ¶

func (o *FindConfigReplaceNodeParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config replace node params

func (*FindConfigReplaceNodeParams) SetTimeout ¶

func (o *FindConfigReplaceNodeParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config replace node params

func (*FindConfigReplaceNodeParams) WithContext ¶

WithContext adds the context to the find config replace node params

func (*FindConfigReplaceNodeParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config replace node params

func (*FindConfigReplaceNodeParams) WithTimeout ¶

WithTimeout adds the timeout to the find config replace node params

func (*FindConfigReplaceNodeParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigReplaceNodeReader ¶

type FindConfigReplaceNodeReader struct {
	// contains filtered or unexported fields
}

FindConfigReplaceNodeReader is a Reader for the FindConfigReplaceNode structure.

func (*FindConfigReplaceNodeReader) ReadResponse ¶

func (o *FindConfigReplaceNodeReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigReplaceTokenDefault ¶

type FindConfigReplaceTokenDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigReplaceTokenDefault handles this case with default header values.

unexpected error

func NewFindConfigReplaceTokenDefault ¶

func NewFindConfigReplaceTokenDefault(code int) *FindConfigReplaceTokenDefault

NewFindConfigReplaceTokenDefault creates a FindConfigReplaceTokenDefault with default headers values

func (*FindConfigReplaceTokenDefault) Code ¶

Code gets the status code for the find config replace token default response

func (*FindConfigReplaceTokenDefault) Error ¶

func (*FindConfigReplaceTokenDefault) GetPayload ¶

type FindConfigReplaceTokenOK ¶

type FindConfigReplaceTokenOK struct {
	Payload string
}

FindConfigReplaceTokenOK handles this case with default header values.

Config value

func NewFindConfigReplaceTokenOK ¶

func NewFindConfigReplaceTokenOK() *FindConfigReplaceTokenOK

NewFindConfigReplaceTokenOK creates a FindConfigReplaceTokenOK with default headers values

func (*FindConfigReplaceTokenOK) GetPayload ¶

func (o *FindConfigReplaceTokenOK) GetPayload() string

type FindConfigReplaceTokenParams ¶

type FindConfigReplaceTokenParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigReplaceTokenParams contains all the parameters to send to the API endpoint for the find config replace token operation typically these are written to a http.Request

func NewFindConfigReplaceTokenParams ¶

func NewFindConfigReplaceTokenParams() *FindConfigReplaceTokenParams

NewFindConfigReplaceTokenParams creates a new FindConfigReplaceTokenParams object with the default values initialized.

func NewFindConfigReplaceTokenParamsWithContext ¶

func NewFindConfigReplaceTokenParamsWithContext(ctx context.Context) *FindConfigReplaceTokenParams

NewFindConfigReplaceTokenParamsWithContext creates a new FindConfigReplaceTokenParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigReplaceTokenParamsWithHTTPClient ¶

func NewFindConfigReplaceTokenParamsWithHTTPClient(client *http.Client) *FindConfigReplaceTokenParams

NewFindConfigReplaceTokenParamsWithHTTPClient creates a new FindConfigReplaceTokenParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigReplaceTokenParamsWithTimeout ¶

func NewFindConfigReplaceTokenParamsWithTimeout(timeout time.Duration) *FindConfigReplaceTokenParams

NewFindConfigReplaceTokenParamsWithTimeout creates a new FindConfigReplaceTokenParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigReplaceTokenParams) SetContext ¶

func (o *FindConfigReplaceTokenParams) SetContext(ctx context.Context)

SetContext adds the context to the find config replace token params

func (*FindConfigReplaceTokenParams) SetHTTPClient ¶

func (o *FindConfigReplaceTokenParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config replace token params

func (*FindConfigReplaceTokenParams) SetTimeout ¶

func (o *FindConfigReplaceTokenParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config replace token params

func (*FindConfigReplaceTokenParams) WithContext ¶

WithContext adds the context to the find config replace token params

func (*FindConfigReplaceTokenParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config replace token params

func (*FindConfigReplaceTokenParams) WithTimeout ¶

WithTimeout adds the timeout to the find config replace token params

func (*FindConfigReplaceTokenParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigReplaceTokenReader ¶

type FindConfigReplaceTokenReader struct {
	// contains filtered or unexported fields
}

FindConfigReplaceTokenReader is a Reader for the FindConfigReplaceToken structure.

func (*FindConfigReplaceTokenReader) ReadResponse ¶

func (o *FindConfigReplaceTokenReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRequestSchedulerDefault ¶

type FindConfigRequestSchedulerDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerDefault handles this case with default header values.

unexpected error

func NewFindConfigRequestSchedulerDefault ¶

func NewFindConfigRequestSchedulerDefault(code int) *FindConfigRequestSchedulerDefault

NewFindConfigRequestSchedulerDefault creates a FindConfigRequestSchedulerDefault with default headers values

func (*FindConfigRequestSchedulerDefault) Code ¶

Code gets the status code for the find config request scheduler default response

func (*FindConfigRequestSchedulerDefault) Error ¶

func (*FindConfigRequestSchedulerDefault) GetPayload ¶

type FindConfigRequestSchedulerIDDefault ¶

type FindConfigRequestSchedulerIDDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerIDDefault handles this case with default header values.

unexpected error

func NewFindConfigRequestSchedulerIDDefault ¶

func NewFindConfigRequestSchedulerIDDefault(code int) *FindConfigRequestSchedulerIDDefault

NewFindConfigRequestSchedulerIDDefault creates a FindConfigRequestSchedulerIDDefault with default headers values

func (*FindConfigRequestSchedulerIDDefault) Code ¶

Code gets the status code for the find config request scheduler id default response

func (*FindConfigRequestSchedulerIDDefault) Error ¶

func (*FindConfigRequestSchedulerIDDefault) GetPayload ¶

type FindConfigRequestSchedulerIDOK ¶

type FindConfigRequestSchedulerIDOK struct {
	Payload string
}

FindConfigRequestSchedulerIDOK handles this case with default header values.

Config value

func NewFindConfigRequestSchedulerIDOK ¶

func NewFindConfigRequestSchedulerIDOK() *FindConfigRequestSchedulerIDOK

NewFindConfigRequestSchedulerIDOK creates a FindConfigRequestSchedulerIDOK with default headers values

func (*FindConfigRequestSchedulerIDOK) GetPayload ¶

func (o *FindConfigRequestSchedulerIDOK) GetPayload() string

type FindConfigRequestSchedulerIDParams ¶

type FindConfigRequestSchedulerIDParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerIDParams contains all the parameters to send to the API endpoint for the find config request scheduler id operation typically these are written to a http.Request

func NewFindConfigRequestSchedulerIDParams ¶

func NewFindConfigRequestSchedulerIDParams() *FindConfigRequestSchedulerIDParams

NewFindConfigRequestSchedulerIDParams creates a new FindConfigRequestSchedulerIDParams object with the default values initialized.

func NewFindConfigRequestSchedulerIDParamsWithContext ¶

func NewFindConfigRequestSchedulerIDParamsWithContext(ctx context.Context) *FindConfigRequestSchedulerIDParams

NewFindConfigRequestSchedulerIDParamsWithContext creates a new FindConfigRequestSchedulerIDParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRequestSchedulerIDParamsWithHTTPClient ¶

func NewFindConfigRequestSchedulerIDParamsWithHTTPClient(client *http.Client) *FindConfigRequestSchedulerIDParams

NewFindConfigRequestSchedulerIDParamsWithHTTPClient creates a new FindConfigRequestSchedulerIDParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRequestSchedulerIDParamsWithTimeout ¶

func NewFindConfigRequestSchedulerIDParamsWithTimeout(timeout time.Duration) *FindConfigRequestSchedulerIDParams

NewFindConfigRequestSchedulerIDParamsWithTimeout creates a new FindConfigRequestSchedulerIDParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRequestSchedulerIDParams) SetContext ¶

SetContext adds the context to the find config request scheduler id params

func (*FindConfigRequestSchedulerIDParams) SetHTTPClient ¶

func (o *FindConfigRequestSchedulerIDParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config request scheduler id params

func (*FindConfigRequestSchedulerIDParams) SetTimeout ¶

func (o *FindConfigRequestSchedulerIDParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config request scheduler id params

func (*FindConfigRequestSchedulerIDParams) WithContext ¶

WithContext adds the context to the find config request scheduler id params

func (*FindConfigRequestSchedulerIDParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config request scheduler id params

func (*FindConfigRequestSchedulerIDParams) WithTimeout ¶

WithTimeout adds the timeout to the find config request scheduler id params

func (*FindConfigRequestSchedulerIDParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRequestSchedulerIDReader ¶

type FindConfigRequestSchedulerIDReader struct {
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerIDReader is a Reader for the FindConfigRequestSchedulerID structure.

func (*FindConfigRequestSchedulerIDReader) ReadResponse ¶

func (o *FindConfigRequestSchedulerIDReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRequestSchedulerOK ¶

type FindConfigRequestSchedulerOK struct {
	Payload string
}

FindConfigRequestSchedulerOK handles this case with default header values.

Config value

func NewFindConfigRequestSchedulerOK ¶

func NewFindConfigRequestSchedulerOK() *FindConfigRequestSchedulerOK

NewFindConfigRequestSchedulerOK creates a FindConfigRequestSchedulerOK with default headers values

func (*FindConfigRequestSchedulerOK) GetPayload ¶

func (o *FindConfigRequestSchedulerOK) GetPayload() string

type FindConfigRequestSchedulerOptionsDefault ¶

type FindConfigRequestSchedulerOptionsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerOptionsDefault handles this case with default header values.

unexpected error

func NewFindConfigRequestSchedulerOptionsDefault ¶

func NewFindConfigRequestSchedulerOptionsDefault(code int) *FindConfigRequestSchedulerOptionsDefault

NewFindConfigRequestSchedulerOptionsDefault creates a FindConfigRequestSchedulerOptionsDefault with default headers values

func (*FindConfigRequestSchedulerOptionsDefault) Code ¶

Code gets the status code for the find config request scheduler options default response

func (*FindConfigRequestSchedulerOptionsDefault) Error ¶

func (*FindConfigRequestSchedulerOptionsDefault) GetPayload ¶

type FindConfigRequestSchedulerOptionsOK ¶

type FindConfigRequestSchedulerOptionsOK struct {
	Payload []string
}

FindConfigRequestSchedulerOptionsOK handles this case with default header values.

Config value

func NewFindConfigRequestSchedulerOptionsOK ¶

func NewFindConfigRequestSchedulerOptionsOK() *FindConfigRequestSchedulerOptionsOK

NewFindConfigRequestSchedulerOptionsOK creates a FindConfigRequestSchedulerOptionsOK with default headers values

func (*FindConfigRequestSchedulerOptionsOK) GetPayload ¶

func (o *FindConfigRequestSchedulerOptionsOK) GetPayload() []string

type FindConfigRequestSchedulerOptionsParams ¶

type FindConfigRequestSchedulerOptionsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerOptionsParams contains all the parameters to send to the API endpoint for the find config request scheduler options operation typically these are written to a http.Request

func NewFindConfigRequestSchedulerOptionsParams ¶

func NewFindConfigRequestSchedulerOptionsParams() *FindConfigRequestSchedulerOptionsParams

NewFindConfigRequestSchedulerOptionsParams creates a new FindConfigRequestSchedulerOptionsParams object with the default values initialized.

func NewFindConfigRequestSchedulerOptionsParamsWithContext ¶

func NewFindConfigRequestSchedulerOptionsParamsWithContext(ctx context.Context) *FindConfigRequestSchedulerOptionsParams

NewFindConfigRequestSchedulerOptionsParamsWithContext creates a new FindConfigRequestSchedulerOptionsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRequestSchedulerOptionsParamsWithHTTPClient ¶

func NewFindConfigRequestSchedulerOptionsParamsWithHTTPClient(client *http.Client) *FindConfigRequestSchedulerOptionsParams

NewFindConfigRequestSchedulerOptionsParamsWithHTTPClient creates a new FindConfigRequestSchedulerOptionsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRequestSchedulerOptionsParamsWithTimeout ¶

func NewFindConfigRequestSchedulerOptionsParamsWithTimeout(timeout time.Duration) *FindConfigRequestSchedulerOptionsParams

NewFindConfigRequestSchedulerOptionsParamsWithTimeout creates a new FindConfigRequestSchedulerOptionsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRequestSchedulerOptionsParams) SetContext ¶

SetContext adds the context to the find config request scheduler options params

func (*FindConfigRequestSchedulerOptionsParams) SetHTTPClient ¶

func (o *FindConfigRequestSchedulerOptionsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config request scheduler options params

func (*FindConfigRequestSchedulerOptionsParams) SetTimeout ¶

func (o *FindConfigRequestSchedulerOptionsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config request scheduler options params

func (*FindConfigRequestSchedulerOptionsParams) WithContext ¶

WithContext adds the context to the find config request scheduler options params

func (*FindConfigRequestSchedulerOptionsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config request scheduler options params

func (*FindConfigRequestSchedulerOptionsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config request scheduler options params

func (*FindConfigRequestSchedulerOptionsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRequestSchedulerOptionsReader ¶

type FindConfigRequestSchedulerOptionsReader struct {
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerOptionsReader is a Reader for the FindConfigRequestSchedulerOptions structure.

func (*FindConfigRequestSchedulerOptionsReader) ReadResponse ¶

func (o *FindConfigRequestSchedulerOptionsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRequestSchedulerParams ¶

type FindConfigRequestSchedulerParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerParams contains all the parameters to send to the API endpoint for the find config request scheduler operation typically these are written to a http.Request

func NewFindConfigRequestSchedulerParams ¶

func NewFindConfigRequestSchedulerParams() *FindConfigRequestSchedulerParams

NewFindConfigRequestSchedulerParams creates a new FindConfigRequestSchedulerParams object with the default values initialized.

func NewFindConfigRequestSchedulerParamsWithContext ¶

func NewFindConfigRequestSchedulerParamsWithContext(ctx context.Context) *FindConfigRequestSchedulerParams

NewFindConfigRequestSchedulerParamsWithContext creates a new FindConfigRequestSchedulerParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRequestSchedulerParamsWithHTTPClient ¶

func NewFindConfigRequestSchedulerParamsWithHTTPClient(client *http.Client) *FindConfigRequestSchedulerParams

NewFindConfigRequestSchedulerParamsWithHTTPClient creates a new FindConfigRequestSchedulerParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRequestSchedulerParamsWithTimeout ¶

func NewFindConfigRequestSchedulerParamsWithTimeout(timeout time.Duration) *FindConfigRequestSchedulerParams

NewFindConfigRequestSchedulerParamsWithTimeout creates a new FindConfigRequestSchedulerParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRequestSchedulerParams) SetContext ¶

SetContext adds the context to the find config request scheduler params

func (*FindConfigRequestSchedulerParams) SetHTTPClient ¶

func (o *FindConfigRequestSchedulerParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config request scheduler params

func (*FindConfigRequestSchedulerParams) SetTimeout ¶

func (o *FindConfigRequestSchedulerParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config request scheduler params

func (*FindConfigRequestSchedulerParams) WithContext ¶

WithContext adds the context to the find config request scheduler params

func (*FindConfigRequestSchedulerParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config request scheduler params

func (*FindConfigRequestSchedulerParams) WithTimeout ¶

WithTimeout adds the timeout to the find config request scheduler params

func (*FindConfigRequestSchedulerParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRequestSchedulerReader ¶

type FindConfigRequestSchedulerReader struct {
	// contains filtered or unexported fields
}

FindConfigRequestSchedulerReader is a Reader for the FindConfigRequestScheduler structure.

func (*FindConfigRequestSchedulerReader) ReadResponse ¶

func (o *FindConfigRequestSchedulerReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRequestTimeoutInMsDefault ¶

type FindConfigRequestTimeoutInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRequestTimeoutInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigRequestTimeoutInMsDefault ¶

func NewFindConfigRequestTimeoutInMsDefault(code int) *FindConfigRequestTimeoutInMsDefault

NewFindConfigRequestTimeoutInMsDefault creates a FindConfigRequestTimeoutInMsDefault with default headers values

func (*FindConfigRequestTimeoutInMsDefault) Code ¶

Code gets the status code for the find config request timeout in ms default response

func (*FindConfigRequestTimeoutInMsDefault) Error ¶

func (*FindConfigRequestTimeoutInMsDefault) GetPayload ¶

type FindConfigRequestTimeoutInMsOK ¶

type FindConfigRequestTimeoutInMsOK struct {
	Payload int64
}

FindConfigRequestTimeoutInMsOK handles this case with default header values.

Config value

func NewFindConfigRequestTimeoutInMsOK ¶

func NewFindConfigRequestTimeoutInMsOK() *FindConfigRequestTimeoutInMsOK

NewFindConfigRequestTimeoutInMsOK creates a FindConfigRequestTimeoutInMsOK with default headers values

func (*FindConfigRequestTimeoutInMsOK) GetPayload ¶

func (o *FindConfigRequestTimeoutInMsOK) GetPayload() int64

type FindConfigRequestTimeoutInMsParams ¶

type FindConfigRequestTimeoutInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRequestTimeoutInMsParams contains all the parameters to send to the API endpoint for the find config request timeout in ms operation typically these are written to a http.Request

func NewFindConfigRequestTimeoutInMsParams ¶

func NewFindConfigRequestTimeoutInMsParams() *FindConfigRequestTimeoutInMsParams

NewFindConfigRequestTimeoutInMsParams creates a new FindConfigRequestTimeoutInMsParams object with the default values initialized.

func NewFindConfigRequestTimeoutInMsParamsWithContext ¶

func NewFindConfigRequestTimeoutInMsParamsWithContext(ctx context.Context) *FindConfigRequestTimeoutInMsParams

NewFindConfigRequestTimeoutInMsParamsWithContext creates a new FindConfigRequestTimeoutInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRequestTimeoutInMsParamsWithHTTPClient ¶

func NewFindConfigRequestTimeoutInMsParamsWithHTTPClient(client *http.Client) *FindConfigRequestTimeoutInMsParams

NewFindConfigRequestTimeoutInMsParamsWithHTTPClient creates a new FindConfigRequestTimeoutInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRequestTimeoutInMsParamsWithTimeout ¶

func NewFindConfigRequestTimeoutInMsParamsWithTimeout(timeout time.Duration) *FindConfigRequestTimeoutInMsParams

NewFindConfigRequestTimeoutInMsParamsWithTimeout creates a new FindConfigRequestTimeoutInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRequestTimeoutInMsParams) SetContext ¶

SetContext adds the context to the find config request timeout in ms params

func (*FindConfigRequestTimeoutInMsParams) SetHTTPClient ¶

func (o *FindConfigRequestTimeoutInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config request timeout in ms params

func (*FindConfigRequestTimeoutInMsParams) SetTimeout ¶

func (o *FindConfigRequestTimeoutInMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config request timeout in ms params

func (*FindConfigRequestTimeoutInMsParams) WithContext ¶

WithContext adds the context to the find config request timeout in ms params

func (*FindConfigRequestTimeoutInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config request timeout in ms params

func (*FindConfigRequestTimeoutInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config request timeout in ms params

func (*FindConfigRequestTimeoutInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRequestTimeoutInMsReader ¶

type FindConfigRequestTimeoutInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigRequestTimeoutInMsReader is a Reader for the FindConfigRequestTimeoutInMs structure.

func (*FindConfigRequestTimeoutInMsReader) ReadResponse ¶

func (o *FindConfigRequestTimeoutInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRingDelayMsDefault ¶

type FindConfigRingDelayMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRingDelayMsDefault handles this case with default header values.

unexpected error

func NewFindConfigRingDelayMsDefault ¶

func NewFindConfigRingDelayMsDefault(code int) *FindConfigRingDelayMsDefault

NewFindConfigRingDelayMsDefault creates a FindConfigRingDelayMsDefault with default headers values

func (*FindConfigRingDelayMsDefault) Code ¶

Code gets the status code for the find config ring delay ms default response

func (*FindConfigRingDelayMsDefault) Error ¶

func (*FindConfigRingDelayMsDefault) GetPayload ¶

type FindConfigRingDelayMsOK ¶

type FindConfigRingDelayMsOK struct {
	Payload int64
}

FindConfigRingDelayMsOK handles this case with default header values.

Config value

func NewFindConfigRingDelayMsOK ¶

func NewFindConfigRingDelayMsOK() *FindConfigRingDelayMsOK

NewFindConfigRingDelayMsOK creates a FindConfigRingDelayMsOK with default headers values

func (*FindConfigRingDelayMsOK) GetPayload ¶

func (o *FindConfigRingDelayMsOK) GetPayload() int64

type FindConfigRingDelayMsParams ¶

type FindConfigRingDelayMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRingDelayMsParams contains all the parameters to send to the API endpoint for the find config ring delay ms operation typically these are written to a http.Request

func NewFindConfigRingDelayMsParams ¶

func NewFindConfigRingDelayMsParams() *FindConfigRingDelayMsParams

NewFindConfigRingDelayMsParams creates a new FindConfigRingDelayMsParams object with the default values initialized.

func NewFindConfigRingDelayMsParamsWithContext ¶

func NewFindConfigRingDelayMsParamsWithContext(ctx context.Context) *FindConfigRingDelayMsParams

NewFindConfigRingDelayMsParamsWithContext creates a new FindConfigRingDelayMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRingDelayMsParamsWithHTTPClient ¶

func NewFindConfigRingDelayMsParamsWithHTTPClient(client *http.Client) *FindConfigRingDelayMsParams

NewFindConfigRingDelayMsParamsWithHTTPClient creates a new FindConfigRingDelayMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRingDelayMsParamsWithTimeout ¶

func NewFindConfigRingDelayMsParamsWithTimeout(timeout time.Duration) *FindConfigRingDelayMsParams

NewFindConfigRingDelayMsParamsWithTimeout creates a new FindConfigRingDelayMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRingDelayMsParams) SetContext ¶

func (o *FindConfigRingDelayMsParams) SetContext(ctx context.Context)

SetContext adds the context to the find config ring delay ms params

func (*FindConfigRingDelayMsParams) SetHTTPClient ¶

func (o *FindConfigRingDelayMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config ring delay ms params

func (*FindConfigRingDelayMsParams) SetTimeout ¶

func (o *FindConfigRingDelayMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config ring delay ms params

func (*FindConfigRingDelayMsParams) WithContext ¶

WithContext adds the context to the find config ring delay ms params

func (*FindConfigRingDelayMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config ring delay ms params

func (*FindConfigRingDelayMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config ring delay ms params

func (*FindConfigRingDelayMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRingDelayMsReader ¶

type FindConfigRingDelayMsReader struct {
	// contains filtered or unexported fields
}

FindConfigRingDelayMsReader is a Reader for the FindConfigRingDelayMs structure.

func (*FindConfigRingDelayMsReader) ReadResponse ¶

func (o *FindConfigRingDelayMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRoleManagerDefault ¶

type FindConfigRoleManagerDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRoleManagerDefault handles this case with default header values.

unexpected error

func NewFindConfigRoleManagerDefault ¶

func NewFindConfigRoleManagerDefault(code int) *FindConfigRoleManagerDefault

NewFindConfigRoleManagerDefault creates a FindConfigRoleManagerDefault with default headers values

func (*FindConfigRoleManagerDefault) Code ¶

Code gets the status code for the find config role manager default response

func (*FindConfigRoleManagerDefault) Error ¶

func (*FindConfigRoleManagerDefault) GetPayload ¶

type FindConfigRoleManagerOK ¶

type FindConfigRoleManagerOK struct {
	Payload string
}

FindConfigRoleManagerOK handles this case with default header values.

Config value

func NewFindConfigRoleManagerOK ¶

func NewFindConfigRoleManagerOK() *FindConfigRoleManagerOK

NewFindConfigRoleManagerOK creates a FindConfigRoleManagerOK with default headers values

func (*FindConfigRoleManagerOK) GetPayload ¶

func (o *FindConfigRoleManagerOK) GetPayload() string

type FindConfigRoleManagerParams ¶

type FindConfigRoleManagerParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRoleManagerParams contains all the parameters to send to the API endpoint for the find config role manager operation typically these are written to a http.Request

func NewFindConfigRoleManagerParams ¶

func NewFindConfigRoleManagerParams() *FindConfigRoleManagerParams

NewFindConfigRoleManagerParams creates a new FindConfigRoleManagerParams object with the default values initialized.

func NewFindConfigRoleManagerParamsWithContext ¶

func NewFindConfigRoleManagerParamsWithContext(ctx context.Context) *FindConfigRoleManagerParams

NewFindConfigRoleManagerParamsWithContext creates a new FindConfigRoleManagerParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRoleManagerParamsWithHTTPClient ¶

func NewFindConfigRoleManagerParamsWithHTTPClient(client *http.Client) *FindConfigRoleManagerParams

NewFindConfigRoleManagerParamsWithHTTPClient creates a new FindConfigRoleManagerParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRoleManagerParamsWithTimeout ¶

func NewFindConfigRoleManagerParamsWithTimeout(timeout time.Duration) *FindConfigRoleManagerParams

NewFindConfigRoleManagerParamsWithTimeout creates a new FindConfigRoleManagerParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRoleManagerParams) SetContext ¶

func (o *FindConfigRoleManagerParams) SetContext(ctx context.Context)

SetContext adds the context to the find config role manager params

func (*FindConfigRoleManagerParams) SetHTTPClient ¶

func (o *FindConfigRoleManagerParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config role manager params

func (*FindConfigRoleManagerParams) SetTimeout ¶

func (o *FindConfigRoleManagerParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config role manager params

func (*FindConfigRoleManagerParams) WithContext ¶

WithContext adds the context to the find config role manager params

func (*FindConfigRoleManagerParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config role manager params

func (*FindConfigRoleManagerParams) WithTimeout ¶

WithTimeout adds the timeout to the find config role manager params

func (*FindConfigRoleManagerParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRoleManagerReader ¶

type FindConfigRoleManagerReader struct {
	// contains filtered or unexported fields
}

FindConfigRoleManagerReader is a Reader for the FindConfigRoleManager structure.

func (*FindConfigRoleManagerReader) ReadResponse ¶

func (o *FindConfigRoleManagerReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRowCacheKeysToSaveDefault ¶

type FindConfigRowCacheKeysToSaveDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRowCacheKeysToSaveDefault handles this case with default header values.

unexpected error

func NewFindConfigRowCacheKeysToSaveDefault ¶

func NewFindConfigRowCacheKeysToSaveDefault(code int) *FindConfigRowCacheKeysToSaveDefault

NewFindConfigRowCacheKeysToSaveDefault creates a FindConfigRowCacheKeysToSaveDefault with default headers values

func (*FindConfigRowCacheKeysToSaveDefault) Code ¶

Code gets the status code for the find config row cache keys to save default response

func (*FindConfigRowCacheKeysToSaveDefault) Error ¶

func (*FindConfigRowCacheKeysToSaveDefault) GetPayload ¶

type FindConfigRowCacheKeysToSaveOK ¶

type FindConfigRowCacheKeysToSaveOK struct {
	Payload int64
}

FindConfigRowCacheKeysToSaveOK handles this case with default header values.

Config value

func NewFindConfigRowCacheKeysToSaveOK ¶

func NewFindConfigRowCacheKeysToSaveOK() *FindConfigRowCacheKeysToSaveOK

NewFindConfigRowCacheKeysToSaveOK creates a FindConfigRowCacheKeysToSaveOK with default headers values

func (*FindConfigRowCacheKeysToSaveOK) GetPayload ¶

func (o *FindConfigRowCacheKeysToSaveOK) GetPayload() int64

type FindConfigRowCacheKeysToSaveParams ¶

type FindConfigRowCacheKeysToSaveParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRowCacheKeysToSaveParams contains all the parameters to send to the API endpoint for the find config row cache keys to save operation typically these are written to a http.Request

func NewFindConfigRowCacheKeysToSaveParams ¶

func NewFindConfigRowCacheKeysToSaveParams() *FindConfigRowCacheKeysToSaveParams

NewFindConfigRowCacheKeysToSaveParams creates a new FindConfigRowCacheKeysToSaveParams object with the default values initialized.

func NewFindConfigRowCacheKeysToSaveParamsWithContext ¶

func NewFindConfigRowCacheKeysToSaveParamsWithContext(ctx context.Context) *FindConfigRowCacheKeysToSaveParams

NewFindConfigRowCacheKeysToSaveParamsWithContext creates a new FindConfigRowCacheKeysToSaveParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRowCacheKeysToSaveParamsWithHTTPClient ¶

func NewFindConfigRowCacheKeysToSaveParamsWithHTTPClient(client *http.Client) *FindConfigRowCacheKeysToSaveParams

NewFindConfigRowCacheKeysToSaveParamsWithHTTPClient creates a new FindConfigRowCacheKeysToSaveParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRowCacheKeysToSaveParamsWithTimeout ¶

func NewFindConfigRowCacheKeysToSaveParamsWithTimeout(timeout time.Duration) *FindConfigRowCacheKeysToSaveParams

NewFindConfigRowCacheKeysToSaveParamsWithTimeout creates a new FindConfigRowCacheKeysToSaveParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRowCacheKeysToSaveParams) SetContext ¶

SetContext adds the context to the find config row cache keys to save params

func (*FindConfigRowCacheKeysToSaveParams) SetHTTPClient ¶

func (o *FindConfigRowCacheKeysToSaveParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config row cache keys to save params

func (*FindConfigRowCacheKeysToSaveParams) SetTimeout ¶

func (o *FindConfigRowCacheKeysToSaveParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config row cache keys to save params

func (*FindConfigRowCacheKeysToSaveParams) WithContext ¶

WithContext adds the context to the find config row cache keys to save params

func (*FindConfigRowCacheKeysToSaveParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config row cache keys to save params

func (*FindConfigRowCacheKeysToSaveParams) WithTimeout ¶

WithTimeout adds the timeout to the find config row cache keys to save params

func (*FindConfigRowCacheKeysToSaveParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRowCacheKeysToSaveReader ¶

type FindConfigRowCacheKeysToSaveReader struct {
	// contains filtered or unexported fields
}

FindConfigRowCacheKeysToSaveReader is a Reader for the FindConfigRowCacheKeysToSave structure.

func (*FindConfigRowCacheKeysToSaveReader) ReadResponse ¶

func (o *FindConfigRowCacheKeysToSaveReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRowCacheSavePeriodDefault ¶

type FindConfigRowCacheSavePeriodDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRowCacheSavePeriodDefault handles this case with default header values.

unexpected error

func NewFindConfigRowCacheSavePeriodDefault ¶

func NewFindConfigRowCacheSavePeriodDefault(code int) *FindConfigRowCacheSavePeriodDefault

NewFindConfigRowCacheSavePeriodDefault creates a FindConfigRowCacheSavePeriodDefault with default headers values

func (*FindConfigRowCacheSavePeriodDefault) Code ¶

Code gets the status code for the find config row cache save period default response

func (*FindConfigRowCacheSavePeriodDefault) Error ¶

func (*FindConfigRowCacheSavePeriodDefault) GetPayload ¶

type FindConfigRowCacheSavePeriodOK ¶

type FindConfigRowCacheSavePeriodOK struct {
	Payload int64
}

FindConfigRowCacheSavePeriodOK handles this case with default header values.

Config value

func NewFindConfigRowCacheSavePeriodOK ¶

func NewFindConfigRowCacheSavePeriodOK() *FindConfigRowCacheSavePeriodOK

NewFindConfigRowCacheSavePeriodOK creates a FindConfigRowCacheSavePeriodOK with default headers values

func (*FindConfigRowCacheSavePeriodOK) GetPayload ¶

func (o *FindConfigRowCacheSavePeriodOK) GetPayload() int64

type FindConfigRowCacheSavePeriodParams ¶

type FindConfigRowCacheSavePeriodParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRowCacheSavePeriodParams contains all the parameters to send to the API endpoint for the find config row cache save period operation typically these are written to a http.Request

func NewFindConfigRowCacheSavePeriodParams ¶

func NewFindConfigRowCacheSavePeriodParams() *FindConfigRowCacheSavePeriodParams

NewFindConfigRowCacheSavePeriodParams creates a new FindConfigRowCacheSavePeriodParams object with the default values initialized.

func NewFindConfigRowCacheSavePeriodParamsWithContext ¶

func NewFindConfigRowCacheSavePeriodParamsWithContext(ctx context.Context) *FindConfigRowCacheSavePeriodParams

NewFindConfigRowCacheSavePeriodParamsWithContext creates a new FindConfigRowCacheSavePeriodParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRowCacheSavePeriodParamsWithHTTPClient ¶

func NewFindConfigRowCacheSavePeriodParamsWithHTTPClient(client *http.Client) *FindConfigRowCacheSavePeriodParams

NewFindConfigRowCacheSavePeriodParamsWithHTTPClient creates a new FindConfigRowCacheSavePeriodParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRowCacheSavePeriodParamsWithTimeout ¶

func NewFindConfigRowCacheSavePeriodParamsWithTimeout(timeout time.Duration) *FindConfigRowCacheSavePeriodParams

NewFindConfigRowCacheSavePeriodParamsWithTimeout creates a new FindConfigRowCacheSavePeriodParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRowCacheSavePeriodParams) SetContext ¶

SetContext adds the context to the find config row cache save period params

func (*FindConfigRowCacheSavePeriodParams) SetHTTPClient ¶

func (o *FindConfigRowCacheSavePeriodParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config row cache save period params

func (*FindConfigRowCacheSavePeriodParams) SetTimeout ¶

func (o *FindConfigRowCacheSavePeriodParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config row cache save period params

func (*FindConfigRowCacheSavePeriodParams) WithContext ¶

WithContext adds the context to the find config row cache save period params

func (*FindConfigRowCacheSavePeriodParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config row cache save period params

func (*FindConfigRowCacheSavePeriodParams) WithTimeout ¶

WithTimeout adds the timeout to the find config row cache save period params

func (*FindConfigRowCacheSavePeriodParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRowCacheSavePeriodReader ¶

type FindConfigRowCacheSavePeriodReader struct {
	// contains filtered or unexported fields
}

FindConfigRowCacheSavePeriodReader is a Reader for the FindConfigRowCacheSavePeriod structure.

func (*FindConfigRowCacheSavePeriodReader) ReadResponse ¶

func (o *FindConfigRowCacheSavePeriodReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigRowCacheSizeInMbDefault ¶

type FindConfigRowCacheSizeInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigRowCacheSizeInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigRowCacheSizeInMbDefault ¶

func NewFindConfigRowCacheSizeInMbDefault(code int) *FindConfigRowCacheSizeInMbDefault

NewFindConfigRowCacheSizeInMbDefault creates a FindConfigRowCacheSizeInMbDefault with default headers values

func (*FindConfigRowCacheSizeInMbDefault) Code ¶

Code gets the status code for the find config row cache size in mb default response

func (*FindConfigRowCacheSizeInMbDefault) Error ¶

func (*FindConfigRowCacheSizeInMbDefault) GetPayload ¶

type FindConfigRowCacheSizeInMbOK ¶

type FindConfigRowCacheSizeInMbOK struct {
	Payload int64
}

FindConfigRowCacheSizeInMbOK handles this case with default header values.

Config value

func NewFindConfigRowCacheSizeInMbOK ¶

func NewFindConfigRowCacheSizeInMbOK() *FindConfigRowCacheSizeInMbOK

NewFindConfigRowCacheSizeInMbOK creates a FindConfigRowCacheSizeInMbOK with default headers values

func (*FindConfigRowCacheSizeInMbOK) GetPayload ¶

func (o *FindConfigRowCacheSizeInMbOK) GetPayload() int64

type FindConfigRowCacheSizeInMbParams ¶

type FindConfigRowCacheSizeInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigRowCacheSizeInMbParams contains all the parameters to send to the API endpoint for the find config row cache size in mb operation typically these are written to a http.Request

func NewFindConfigRowCacheSizeInMbParams ¶

func NewFindConfigRowCacheSizeInMbParams() *FindConfigRowCacheSizeInMbParams

NewFindConfigRowCacheSizeInMbParams creates a new FindConfigRowCacheSizeInMbParams object with the default values initialized.

func NewFindConfigRowCacheSizeInMbParamsWithContext ¶

func NewFindConfigRowCacheSizeInMbParamsWithContext(ctx context.Context) *FindConfigRowCacheSizeInMbParams

NewFindConfigRowCacheSizeInMbParamsWithContext creates a new FindConfigRowCacheSizeInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigRowCacheSizeInMbParamsWithHTTPClient ¶

func NewFindConfigRowCacheSizeInMbParamsWithHTTPClient(client *http.Client) *FindConfigRowCacheSizeInMbParams

NewFindConfigRowCacheSizeInMbParamsWithHTTPClient creates a new FindConfigRowCacheSizeInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigRowCacheSizeInMbParamsWithTimeout ¶

func NewFindConfigRowCacheSizeInMbParamsWithTimeout(timeout time.Duration) *FindConfigRowCacheSizeInMbParams

NewFindConfigRowCacheSizeInMbParamsWithTimeout creates a new FindConfigRowCacheSizeInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigRowCacheSizeInMbParams) SetContext ¶

SetContext adds the context to the find config row cache size in mb params

func (*FindConfigRowCacheSizeInMbParams) SetHTTPClient ¶

func (o *FindConfigRowCacheSizeInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config row cache size in mb params

func (*FindConfigRowCacheSizeInMbParams) SetTimeout ¶

func (o *FindConfigRowCacheSizeInMbParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config row cache size in mb params

func (*FindConfigRowCacheSizeInMbParams) WithContext ¶

WithContext adds the context to the find config row cache size in mb params

func (*FindConfigRowCacheSizeInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config row cache size in mb params

func (*FindConfigRowCacheSizeInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config row cache size in mb params

func (*FindConfigRowCacheSizeInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigRowCacheSizeInMbReader ¶

type FindConfigRowCacheSizeInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigRowCacheSizeInMbReader is a Reader for the FindConfigRowCacheSizeInMb structure.

func (*FindConfigRowCacheSizeInMbReader) ReadResponse ¶

func (o *FindConfigRowCacheSizeInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigSavedCachesDirectoryDefault ¶

type FindConfigSavedCachesDirectoryDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigSavedCachesDirectoryDefault handles this case with default header values.

unexpected error

func NewFindConfigSavedCachesDirectoryDefault ¶

func NewFindConfigSavedCachesDirectoryDefault(code int) *FindConfigSavedCachesDirectoryDefault

NewFindConfigSavedCachesDirectoryDefault creates a FindConfigSavedCachesDirectoryDefault with default headers values

func (*FindConfigSavedCachesDirectoryDefault) Code ¶

Code gets the status code for the find config saved caches directory default response

func (*FindConfigSavedCachesDirectoryDefault) Error ¶

func (*FindConfigSavedCachesDirectoryDefault) GetPayload ¶

type FindConfigSavedCachesDirectoryOK ¶

type FindConfigSavedCachesDirectoryOK struct {
	Payload string
}

FindConfigSavedCachesDirectoryOK handles this case with default header values.

Config value

func NewFindConfigSavedCachesDirectoryOK ¶

func NewFindConfigSavedCachesDirectoryOK() *FindConfigSavedCachesDirectoryOK

NewFindConfigSavedCachesDirectoryOK creates a FindConfigSavedCachesDirectoryOK with default headers values

func (*FindConfigSavedCachesDirectoryOK) GetPayload ¶

func (o *FindConfigSavedCachesDirectoryOK) GetPayload() string

type FindConfigSavedCachesDirectoryParams ¶

type FindConfigSavedCachesDirectoryParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigSavedCachesDirectoryParams contains all the parameters to send to the API endpoint for the find config saved caches directory operation typically these are written to a http.Request

func NewFindConfigSavedCachesDirectoryParams ¶

func NewFindConfigSavedCachesDirectoryParams() *FindConfigSavedCachesDirectoryParams

NewFindConfigSavedCachesDirectoryParams creates a new FindConfigSavedCachesDirectoryParams object with the default values initialized.

func NewFindConfigSavedCachesDirectoryParamsWithContext ¶

func NewFindConfigSavedCachesDirectoryParamsWithContext(ctx context.Context) *FindConfigSavedCachesDirectoryParams

NewFindConfigSavedCachesDirectoryParamsWithContext creates a new FindConfigSavedCachesDirectoryParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigSavedCachesDirectoryParamsWithHTTPClient ¶

func NewFindConfigSavedCachesDirectoryParamsWithHTTPClient(client *http.Client) *FindConfigSavedCachesDirectoryParams

NewFindConfigSavedCachesDirectoryParamsWithHTTPClient creates a new FindConfigSavedCachesDirectoryParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigSavedCachesDirectoryParamsWithTimeout ¶

func NewFindConfigSavedCachesDirectoryParamsWithTimeout(timeout time.Duration) *FindConfigSavedCachesDirectoryParams

NewFindConfigSavedCachesDirectoryParamsWithTimeout creates a new FindConfigSavedCachesDirectoryParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigSavedCachesDirectoryParams) SetContext ¶

SetContext adds the context to the find config saved caches directory params

func (*FindConfigSavedCachesDirectoryParams) SetHTTPClient ¶

func (o *FindConfigSavedCachesDirectoryParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config saved caches directory params

func (*FindConfigSavedCachesDirectoryParams) SetTimeout ¶

func (o *FindConfigSavedCachesDirectoryParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config saved caches directory params

func (*FindConfigSavedCachesDirectoryParams) WithContext ¶

WithContext adds the context to the find config saved caches directory params

func (*FindConfigSavedCachesDirectoryParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config saved caches directory params

func (*FindConfigSavedCachesDirectoryParams) WithTimeout ¶

WithTimeout adds the timeout to the find config saved caches directory params

func (*FindConfigSavedCachesDirectoryParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigSavedCachesDirectoryReader ¶

type FindConfigSavedCachesDirectoryReader struct {
	// contains filtered or unexported fields
}

FindConfigSavedCachesDirectoryReader is a Reader for the FindConfigSavedCachesDirectory structure.

func (*FindConfigSavedCachesDirectoryReader) ReadResponse ¶

func (o *FindConfigSavedCachesDirectoryReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigSeedProviderDefault ¶

type FindConfigSeedProviderDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigSeedProviderDefault handles this case with default header values.

unexpected error

func NewFindConfigSeedProviderDefault ¶

func NewFindConfigSeedProviderDefault(code int) *FindConfigSeedProviderDefault

NewFindConfigSeedProviderDefault creates a FindConfigSeedProviderDefault with default headers values

func (*FindConfigSeedProviderDefault) Code ¶

Code gets the status code for the find config seed provider default response

func (*FindConfigSeedProviderDefault) Error ¶

func (*FindConfigSeedProviderDefault) GetPayload ¶

type FindConfigSeedProviderOK ¶

type FindConfigSeedProviderOK struct {
	Payload []string
}

FindConfigSeedProviderOK handles this case with default header values.

Config value

func NewFindConfigSeedProviderOK ¶

func NewFindConfigSeedProviderOK() *FindConfigSeedProviderOK

NewFindConfigSeedProviderOK creates a FindConfigSeedProviderOK with default headers values

func (*FindConfigSeedProviderOK) GetPayload ¶

func (o *FindConfigSeedProviderOK) GetPayload() []string

type FindConfigSeedProviderParams ¶

type FindConfigSeedProviderParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigSeedProviderParams contains all the parameters to send to the API endpoint for the find config seed provider operation typically these are written to a http.Request

func NewFindConfigSeedProviderParams ¶

func NewFindConfigSeedProviderParams() *FindConfigSeedProviderParams

NewFindConfigSeedProviderParams creates a new FindConfigSeedProviderParams object with the default values initialized.

func NewFindConfigSeedProviderParamsWithContext ¶

func NewFindConfigSeedProviderParamsWithContext(ctx context.Context) *FindConfigSeedProviderParams

NewFindConfigSeedProviderParamsWithContext creates a new FindConfigSeedProviderParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigSeedProviderParamsWithHTTPClient ¶

func NewFindConfigSeedProviderParamsWithHTTPClient(client *http.Client) *FindConfigSeedProviderParams

NewFindConfigSeedProviderParamsWithHTTPClient creates a new FindConfigSeedProviderParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigSeedProviderParamsWithTimeout ¶

func NewFindConfigSeedProviderParamsWithTimeout(timeout time.Duration) *FindConfigSeedProviderParams

NewFindConfigSeedProviderParamsWithTimeout creates a new FindConfigSeedProviderParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigSeedProviderParams) SetContext ¶

func (o *FindConfigSeedProviderParams) SetContext(ctx context.Context)

SetContext adds the context to the find config seed provider params

func (*FindConfigSeedProviderParams) SetHTTPClient ¶

func (o *FindConfigSeedProviderParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config seed provider params

func (*FindConfigSeedProviderParams) SetTimeout ¶

func (o *FindConfigSeedProviderParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config seed provider params

func (*FindConfigSeedProviderParams) WithContext ¶

WithContext adds the context to the find config seed provider params

func (*FindConfigSeedProviderParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config seed provider params

func (*FindConfigSeedProviderParams) WithTimeout ¶

WithTimeout adds the timeout to the find config seed provider params

func (*FindConfigSeedProviderParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigSeedProviderReader ¶

type FindConfigSeedProviderReader struct {
	// contains filtered or unexported fields
}

FindConfigSeedProviderReader is a Reader for the FindConfigSeedProvider structure.

func (*FindConfigSeedProviderReader) ReadResponse ¶

func (o *FindConfigSeedProviderReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigServerEncryptionOptionsDefault ¶

type FindConfigServerEncryptionOptionsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigServerEncryptionOptionsDefault handles this case with default header values.

unexpected error

func NewFindConfigServerEncryptionOptionsDefault ¶

func NewFindConfigServerEncryptionOptionsDefault(code int) *FindConfigServerEncryptionOptionsDefault

NewFindConfigServerEncryptionOptionsDefault creates a FindConfigServerEncryptionOptionsDefault with default headers values

func (*FindConfigServerEncryptionOptionsDefault) Code ¶

Code gets the status code for the find config server encryption options default response

func (*FindConfigServerEncryptionOptionsDefault) Error ¶

func (*FindConfigServerEncryptionOptionsDefault) GetPayload ¶

type FindConfigServerEncryptionOptionsOK ¶

type FindConfigServerEncryptionOptionsOK struct {
	Payload []string
}

FindConfigServerEncryptionOptionsOK handles this case with default header values.

Config value

func NewFindConfigServerEncryptionOptionsOK ¶

func NewFindConfigServerEncryptionOptionsOK() *FindConfigServerEncryptionOptionsOK

NewFindConfigServerEncryptionOptionsOK creates a FindConfigServerEncryptionOptionsOK with default headers values

func (*FindConfigServerEncryptionOptionsOK) GetPayload ¶

func (o *FindConfigServerEncryptionOptionsOK) GetPayload() []string

type FindConfigServerEncryptionOptionsParams ¶

type FindConfigServerEncryptionOptionsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigServerEncryptionOptionsParams contains all the parameters to send to the API endpoint for the find config server encryption options operation typically these are written to a http.Request

func NewFindConfigServerEncryptionOptionsParams ¶

func NewFindConfigServerEncryptionOptionsParams() *FindConfigServerEncryptionOptionsParams

NewFindConfigServerEncryptionOptionsParams creates a new FindConfigServerEncryptionOptionsParams object with the default values initialized.

func NewFindConfigServerEncryptionOptionsParamsWithContext ¶

func NewFindConfigServerEncryptionOptionsParamsWithContext(ctx context.Context) *FindConfigServerEncryptionOptionsParams

NewFindConfigServerEncryptionOptionsParamsWithContext creates a new FindConfigServerEncryptionOptionsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigServerEncryptionOptionsParamsWithHTTPClient ¶

func NewFindConfigServerEncryptionOptionsParamsWithHTTPClient(client *http.Client) *FindConfigServerEncryptionOptionsParams

NewFindConfigServerEncryptionOptionsParamsWithHTTPClient creates a new FindConfigServerEncryptionOptionsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigServerEncryptionOptionsParamsWithTimeout ¶

func NewFindConfigServerEncryptionOptionsParamsWithTimeout(timeout time.Duration) *FindConfigServerEncryptionOptionsParams

NewFindConfigServerEncryptionOptionsParamsWithTimeout creates a new FindConfigServerEncryptionOptionsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigServerEncryptionOptionsParams) SetContext ¶

SetContext adds the context to the find config server encryption options params

func (*FindConfigServerEncryptionOptionsParams) SetHTTPClient ¶

func (o *FindConfigServerEncryptionOptionsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config server encryption options params

func (*FindConfigServerEncryptionOptionsParams) SetTimeout ¶

func (o *FindConfigServerEncryptionOptionsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config server encryption options params

func (*FindConfigServerEncryptionOptionsParams) WithContext ¶

WithContext adds the context to the find config server encryption options params

func (*FindConfigServerEncryptionOptionsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config server encryption options params

func (*FindConfigServerEncryptionOptionsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config server encryption options params

func (*FindConfigServerEncryptionOptionsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigServerEncryptionOptionsReader ¶

type FindConfigServerEncryptionOptionsReader struct {
	// contains filtered or unexported fields
}

FindConfigServerEncryptionOptionsReader is a Reader for the FindConfigServerEncryptionOptions structure.

func (*FindConfigServerEncryptionOptionsReader) ReadResponse ¶

func (o *FindConfigServerEncryptionOptionsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigShadowRoundMsDefault ¶

type FindConfigShadowRoundMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigShadowRoundMsDefault handles this case with default header values.

unexpected error

func NewFindConfigShadowRoundMsDefault ¶

func NewFindConfigShadowRoundMsDefault(code int) *FindConfigShadowRoundMsDefault

NewFindConfigShadowRoundMsDefault creates a FindConfigShadowRoundMsDefault with default headers values

func (*FindConfigShadowRoundMsDefault) Code ¶

Code gets the status code for the find config shadow round ms default response

func (*FindConfigShadowRoundMsDefault) Error ¶

func (*FindConfigShadowRoundMsDefault) GetPayload ¶

type FindConfigShadowRoundMsOK ¶

type FindConfigShadowRoundMsOK struct {
	Payload int64
}

FindConfigShadowRoundMsOK handles this case with default header values.

Config value

func NewFindConfigShadowRoundMsOK ¶

func NewFindConfigShadowRoundMsOK() *FindConfigShadowRoundMsOK

NewFindConfigShadowRoundMsOK creates a FindConfigShadowRoundMsOK with default headers values

func (*FindConfigShadowRoundMsOK) GetPayload ¶

func (o *FindConfigShadowRoundMsOK) GetPayload() int64

type FindConfigShadowRoundMsParams ¶

type FindConfigShadowRoundMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigShadowRoundMsParams contains all the parameters to send to the API endpoint for the find config shadow round ms operation typically these are written to a http.Request

func NewFindConfigShadowRoundMsParams ¶

func NewFindConfigShadowRoundMsParams() *FindConfigShadowRoundMsParams

NewFindConfigShadowRoundMsParams creates a new FindConfigShadowRoundMsParams object with the default values initialized.

func NewFindConfigShadowRoundMsParamsWithContext ¶

func NewFindConfigShadowRoundMsParamsWithContext(ctx context.Context) *FindConfigShadowRoundMsParams

NewFindConfigShadowRoundMsParamsWithContext creates a new FindConfigShadowRoundMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigShadowRoundMsParamsWithHTTPClient ¶

func NewFindConfigShadowRoundMsParamsWithHTTPClient(client *http.Client) *FindConfigShadowRoundMsParams

NewFindConfigShadowRoundMsParamsWithHTTPClient creates a new FindConfigShadowRoundMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigShadowRoundMsParamsWithTimeout ¶

func NewFindConfigShadowRoundMsParamsWithTimeout(timeout time.Duration) *FindConfigShadowRoundMsParams

NewFindConfigShadowRoundMsParamsWithTimeout creates a new FindConfigShadowRoundMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigShadowRoundMsParams) SetContext ¶

func (o *FindConfigShadowRoundMsParams) SetContext(ctx context.Context)

SetContext adds the context to the find config shadow round ms params

func (*FindConfigShadowRoundMsParams) SetHTTPClient ¶

func (o *FindConfigShadowRoundMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config shadow round ms params

func (*FindConfigShadowRoundMsParams) SetTimeout ¶

func (o *FindConfigShadowRoundMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config shadow round ms params

func (*FindConfigShadowRoundMsParams) WithContext ¶

WithContext adds the context to the find config shadow round ms params

func (*FindConfigShadowRoundMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config shadow round ms params

func (*FindConfigShadowRoundMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config shadow round ms params

func (*FindConfigShadowRoundMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigShadowRoundMsReader ¶

type FindConfigShadowRoundMsReader struct {
	// contains filtered or unexported fields
}

FindConfigShadowRoundMsReader is a Reader for the FindConfigShadowRoundMs structure.

func (*FindConfigShadowRoundMsReader) ReadResponse ¶

func (o *FindConfigShadowRoundMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigShutdownAnnounceInMsDefault ¶

type FindConfigShutdownAnnounceInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigShutdownAnnounceInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigShutdownAnnounceInMsDefault ¶

func NewFindConfigShutdownAnnounceInMsDefault(code int) *FindConfigShutdownAnnounceInMsDefault

NewFindConfigShutdownAnnounceInMsDefault creates a FindConfigShutdownAnnounceInMsDefault with default headers values

func (*FindConfigShutdownAnnounceInMsDefault) Code ¶

Code gets the status code for the find config shutdown announce in ms default response

func (*FindConfigShutdownAnnounceInMsDefault) Error ¶

func (*FindConfigShutdownAnnounceInMsDefault) GetPayload ¶

type FindConfigShutdownAnnounceInMsOK ¶

type FindConfigShutdownAnnounceInMsOK struct {
	Payload int64
}

FindConfigShutdownAnnounceInMsOK handles this case with default header values.

Config value

func NewFindConfigShutdownAnnounceInMsOK ¶

func NewFindConfigShutdownAnnounceInMsOK() *FindConfigShutdownAnnounceInMsOK

NewFindConfigShutdownAnnounceInMsOK creates a FindConfigShutdownAnnounceInMsOK with default headers values

func (*FindConfigShutdownAnnounceInMsOK) GetPayload ¶

func (o *FindConfigShutdownAnnounceInMsOK) GetPayload() int64

type FindConfigShutdownAnnounceInMsParams ¶

type FindConfigShutdownAnnounceInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigShutdownAnnounceInMsParams contains all the parameters to send to the API endpoint for the find config shutdown announce in ms operation typically these are written to a http.Request

func NewFindConfigShutdownAnnounceInMsParams ¶

func NewFindConfigShutdownAnnounceInMsParams() *FindConfigShutdownAnnounceInMsParams

NewFindConfigShutdownAnnounceInMsParams creates a new FindConfigShutdownAnnounceInMsParams object with the default values initialized.

func NewFindConfigShutdownAnnounceInMsParamsWithContext ¶

func NewFindConfigShutdownAnnounceInMsParamsWithContext(ctx context.Context) *FindConfigShutdownAnnounceInMsParams

NewFindConfigShutdownAnnounceInMsParamsWithContext creates a new FindConfigShutdownAnnounceInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigShutdownAnnounceInMsParamsWithHTTPClient ¶

func NewFindConfigShutdownAnnounceInMsParamsWithHTTPClient(client *http.Client) *FindConfigShutdownAnnounceInMsParams

NewFindConfigShutdownAnnounceInMsParamsWithHTTPClient creates a new FindConfigShutdownAnnounceInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigShutdownAnnounceInMsParamsWithTimeout ¶

func NewFindConfigShutdownAnnounceInMsParamsWithTimeout(timeout time.Duration) *FindConfigShutdownAnnounceInMsParams

NewFindConfigShutdownAnnounceInMsParamsWithTimeout creates a new FindConfigShutdownAnnounceInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigShutdownAnnounceInMsParams) SetContext ¶

SetContext adds the context to the find config shutdown announce in ms params

func (*FindConfigShutdownAnnounceInMsParams) SetHTTPClient ¶

func (o *FindConfigShutdownAnnounceInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config shutdown announce in ms params

func (*FindConfigShutdownAnnounceInMsParams) SetTimeout ¶

func (o *FindConfigShutdownAnnounceInMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config shutdown announce in ms params

func (*FindConfigShutdownAnnounceInMsParams) WithContext ¶

WithContext adds the context to the find config shutdown announce in ms params

func (*FindConfigShutdownAnnounceInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config shutdown announce in ms params

func (*FindConfigShutdownAnnounceInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config shutdown announce in ms params

func (*FindConfigShutdownAnnounceInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigShutdownAnnounceInMsReader ¶

type FindConfigShutdownAnnounceInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigShutdownAnnounceInMsReader is a Reader for the FindConfigShutdownAnnounceInMs structure.

func (*FindConfigShutdownAnnounceInMsReader) ReadResponse ¶

func (o *FindConfigShutdownAnnounceInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigSkipWaitForGossipToSettleDefault ¶

type FindConfigSkipWaitForGossipToSettleDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigSkipWaitForGossipToSettleDefault handles this case with default header values.

unexpected error

func NewFindConfigSkipWaitForGossipToSettleDefault ¶

func NewFindConfigSkipWaitForGossipToSettleDefault(code int) *FindConfigSkipWaitForGossipToSettleDefault

NewFindConfigSkipWaitForGossipToSettleDefault creates a FindConfigSkipWaitForGossipToSettleDefault with default headers values

func (*FindConfigSkipWaitForGossipToSettleDefault) Code ¶

Code gets the status code for the find config skip wait for gossip to settle default response

func (*FindConfigSkipWaitForGossipToSettleDefault) Error ¶

func (*FindConfigSkipWaitForGossipToSettleDefault) GetPayload ¶

type FindConfigSkipWaitForGossipToSettleOK ¶

type FindConfigSkipWaitForGossipToSettleOK struct {
	Payload int64
}

FindConfigSkipWaitForGossipToSettleOK handles this case with default header values.

Config value

func NewFindConfigSkipWaitForGossipToSettleOK ¶

func NewFindConfigSkipWaitForGossipToSettleOK() *FindConfigSkipWaitForGossipToSettleOK

NewFindConfigSkipWaitForGossipToSettleOK creates a FindConfigSkipWaitForGossipToSettleOK with default headers values

func (*FindConfigSkipWaitForGossipToSettleOK) GetPayload ¶

type FindConfigSkipWaitForGossipToSettleParams ¶

type FindConfigSkipWaitForGossipToSettleParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigSkipWaitForGossipToSettleParams contains all the parameters to send to the API endpoint for the find config skip wait for gossip to settle operation typically these are written to a http.Request

func NewFindConfigSkipWaitForGossipToSettleParams ¶

func NewFindConfigSkipWaitForGossipToSettleParams() *FindConfigSkipWaitForGossipToSettleParams

NewFindConfigSkipWaitForGossipToSettleParams creates a new FindConfigSkipWaitForGossipToSettleParams object with the default values initialized.

func NewFindConfigSkipWaitForGossipToSettleParamsWithContext ¶

func NewFindConfigSkipWaitForGossipToSettleParamsWithContext(ctx context.Context) *FindConfigSkipWaitForGossipToSettleParams

NewFindConfigSkipWaitForGossipToSettleParamsWithContext creates a new FindConfigSkipWaitForGossipToSettleParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigSkipWaitForGossipToSettleParamsWithHTTPClient ¶

func NewFindConfigSkipWaitForGossipToSettleParamsWithHTTPClient(client *http.Client) *FindConfigSkipWaitForGossipToSettleParams

NewFindConfigSkipWaitForGossipToSettleParamsWithHTTPClient creates a new FindConfigSkipWaitForGossipToSettleParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigSkipWaitForGossipToSettleParamsWithTimeout ¶

func NewFindConfigSkipWaitForGossipToSettleParamsWithTimeout(timeout time.Duration) *FindConfigSkipWaitForGossipToSettleParams

NewFindConfigSkipWaitForGossipToSettleParamsWithTimeout creates a new FindConfigSkipWaitForGossipToSettleParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigSkipWaitForGossipToSettleParams) SetContext ¶

SetContext adds the context to the find config skip wait for gossip to settle params

func (*FindConfigSkipWaitForGossipToSettleParams) SetHTTPClient ¶

func (o *FindConfigSkipWaitForGossipToSettleParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config skip wait for gossip to settle params

func (*FindConfigSkipWaitForGossipToSettleParams) SetTimeout ¶

SetTimeout adds the timeout to the find config skip wait for gossip to settle params

func (*FindConfigSkipWaitForGossipToSettleParams) WithContext ¶

WithContext adds the context to the find config skip wait for gossip to settle params

func (*FindConfigSkipWaitForGossipToSettleParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config skip wait for gossip to settle params

func (*FindConfigSkipWaitForGossipToSettleParams) WithTimeout ¶

WithTimeout adds the timeout to the find config skip wait for gossip to settle params

func (*FindConfigSkipWaitForGossipToSettleParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigSkipWaitForGossipToSettleReader ¶

type FindConfigSkipWaitForGossipToSettleReader struct {
	// contains filtered or unexported fields
}

FindConfigSkipWaitForGossipToSettleReader is a Reader for the FindConfigSkipWaitForGossipToSettle structure.

func (*FindConfigSkipWaitForGossipToSettleReader) ReadResponse ¶

func (o *FindConfigSkipWaitForGossipToSettleReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigSnapshotBeforeCompactionDefault ¶

type FindConfigSnapshotBeforeCompactionDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigSnapshotBeforeCompactionDefault handles this case with default header values.

unexpected error

func NewFindConfigSnapshotBeforeCompactionDefault ¶

func NewFindConfigSnapshotBeforeCompactionDefault(code int) *FindConfigSnapshotBeforeCompactionDefault

NewFindConfigSnapshotBeforeCompactionDefault creates a FindConfigSnapshotBeforeCompactionDefault with default headers values

func (*FindConfigSnapshotBeforeCompactionDefault) Code ¶

Code gets the status code for the find config snapshot before compaction default response

func (*FindConfigSnapshotBeforeCompactionDefault) Error ¶

func (*FindConfigSnapshotBeforeCompactionDefault) GetPayload ¶

type FindConfigSnapshotBeforeCompactionOK ¶

type FindConfigSnapshotBeforeCompactionOK struct {
	Payload bool
}

FindConfigSnapshotBeforeCompactionOK handles this case with default header values.

Config value

func NewFindConfigSnapshotBeforeCompactionOK ¶

func NewFindConfigSnapshotBeforeCompactionOK() *FindConfigSnapshotBeforeCompactionOK

NewFindConfigSnapshotBeforeCompactionOK creates a FindConfigSnapshotBeforeCompactionOK with default headers values

func (*FindConfigSnapshotBeforeCompactionOK) GetPayload ¶

type FindConfigSnapshotBeforeCompactionParams ¶

type FindConfigSnapshotBeforeCompactionParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigSnapshotBeforeCompactionParams contains all the parameters to send to the API endpoint for the find config snapshot before compaction operation typically these are written to a http.Request

func NewFindConfigSnapshotBeforeCompactionParams ¶

func NewFindConfigSnapshotBeforeCompactionParams() *FindConfigSnapshotBeforeCompactionParams

NewFindConfigSnapshotBeforeCompactionParams creates a new FindConfigSnapshotBeforeCompactionParams object with the default values initialized.

func NewFindConfigSnapshotBeforeCompactionParamsWithContext ¶

func NewFindConfigSnapshotBeforeCompactionParamsWithContext(ctx context.Context) *FindConfigSnapshotBeforeCompactionParams

NewFindConfigSnapshotBeforeCompactionParamsWithContext creates a new FindConfigSnapshotBeforeCompactionParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigSnapshotBeforeCompactionParamsWithHTTPClient ¶

func NewFindConfigSnapshotBeforeCompactionParamsWithHTTPClient(client *http.Client) *FindConfigSnapshotBeforeCompactionParams

NewFindConfigSnapshotBeforeCompactionParamsWithHTTPClient creates a new FindConfigSnapshotBeforeCompactionParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigSnapshotBeforeCompactionParamsWithTimeout ¶

func NewFindConfigSnapshotBeforeCompactionParamsWithTimeout(timeout time.Duration) *FindConfigSnapshotBeforeCompactionParams

NewFindConfigSnapshotBeforeCompactionParamsWithTimeout creates a new FindConfigSnapshotBeforeCompactionParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigSnapshotBeforeCompactionParams) SetContext ¶

SetContext adds the context to the find config snapshot before compaction params

func (*FindConfigSnapshotBeforeCompactionParams) SetHTTPClient ¶

func (o *FindConfigSnapshotBeforeCompactionParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config snapshot before compaction params

func (*FindConfigSnapshotBeforeCompactionParams) SetTimeout ¶

SetTimeout adds the timeout to the find config snapshot before compaction params

func (*FindConfigSnapshotBeforeCompactionParams) WithContext ¶

WithContext adds the context to the find config snapshot before compaction params

func (*FindConfigSnapshotBeforeCompactionParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config snapshot before compaction params

func (*FindConfigSnapshotBeforeCompactionParams) WithTimeout ¶

WithTimeout adds the timeout to the find config snapshot before compaction params

func (*FindConfigSnapshotBeforeCompactionParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigSnapshotBeforeCompactionReader ¶

type FindConfigSnapshotBeforeCompactionReader struct {
	// contains filtered or unexported fields
}

FindConfigSnapshotBeforeCompactionReader is a Reader for the FindConfigSnapshotBeforeCompaction structure.

func (*FindConfigSnapshotBeforeCompactionReader) ReadResponse ¶

func (o *FindConfigSnapshotBeforeCompactionReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigSslStoragePortDefault ¶

type FindConfigSslStoragePortDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigSslStoragePortDefault handles this case with default header values.

unexpected error

func NewFindConfigSslStoragePortDefault ¶

func NewFindConfigSslStoragePortDefault(code int) *FindConfigSslStoragePortDefault

NewFindConfigSslStoragePortDefault creates a FindConfigSslStoragePortDefault with default headers values

func (*FindConfigSslStoragePortDefault) Code ¶

Code gets the status code for the find config ssl storage port default response

func (*FindConfigSslStoragePortDefault) Error ¶

func (*FindConfigSslStoragePortDefault) GetPayload ¶

type FindConfigSslStoragePortOK ¶

type FindConfigSslStoragePortOK struct {
	Payload int64
}

FindConfigSslStoragePortOK handles this case with default header values.

Config value

func NewFindConfigSslStoragePortOK ¶

func NewFindConfigSslStoragePortOK() *FindConfigSslStoragePortOK

NewFindConfigSslStoragePortOK creates a FindConfigSslStoragePortOK with default headers values

func (*FindConfigSslStoragePortOK) GetPayload ¶

func (o *FindConfigSslStoragePortOK) GetPayload() int64

type FindConfigSslStoragePortParams ¶

type FindConfigSslStoragePortParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigSslStoragePortParams contains all the parameters to send to the API endpoint for the find config ssl storage port operation typically these are written to a http.Request

func NewFindConfigSslStoragePortParams ¶

func NewFindConfigSslStoragePortParams() *FindConfigSslStoragePortParams

NewFindConfigSslStoragePortParams creates a new FindConfigSslStoragePortParams object with the default values initialized.

func NewFindConfigSslStoragePortParamsWithContext ¶

func NewFindConfigSslStoragePortParamsWithContext(ctx context.Context) *FindConfigSslStoragePortParams

NewFindConfigSslStoragePortParamsWithContext creates a new FindConfigSslStoragePortParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigSslStoragePortParamsWithHTTPClient ¶

func NewFindConfigSslStoragePortParamsWithHTTPClient(client *http.Client) *FindConfigSslStoragePortParams

NewFindConfigSslStoragePortParamsWithHTTPClient creates a new FindConfigSslStoragePortParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigSslStoragePortParamsWithTimeout ¶

func NewFindConfigSslStoragePortParamsWithTimeout(timeout time.Duration) *FindConfigSslStoragePortParams

NewFindConfigSslStoragePortParamsWithTimeout creates a new FindConfigSslStoragePortParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigSslStoragePortParams) SetContext ¶

func (o *FindConfigSslStoragePortParams) SetContext(ctx context.Context)

SetContext adds the context to the find config ssl storage port params

func (*FindConfigSslStoragePortParams) SetHTTPClient ¶

func (o *FindConfigSslStoragePortParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config ssl storage port params

func (*FindConfigSslStoragePortParams) SetTimeout ¶

func (o *FindConfigSslStoragePortParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config ssl storage port params

func (*FindConfigSslStoragePortParams) WithContext ¶

WithContext adds the context to the find config ssl storage port params

func (*FindConfigSslStoragePortParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config ssl storage port params

func (*FindConfigSslStoragePortParams) WithTimeout ¶

WithTimeout adds the timeout to the find config ssl storage port params

func (*FindConfigSslStoragePortParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigSslStoragePortReader ¶

type FindConfigSslStoragePortReader struct {
	// contains filtered or unexported fields
}

FindConfigSslStoragePortReader is a Reader for the FindConfigSslStoragePort structure.

func (*FindConfigSslStoragePortReader) ReadResponse ¶

func (o *FindConfigSslStoragePortReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigSstablePreemptiveOpenIntervalInMbDefault ¶

type FindConfigSstablePreemptiveOpenIntervalInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigSstablePreemptiveOpenIntervalInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigSstablePreemptiveOpenIntervalInMbDefault ¶

func NewFindConfigSstablePreemptiveOpenIntervalInMbDefault(code int) *FindConfigSstablePreemptiveOpenIntervalInMbDefault

NewFindConfigSstablePreemptiveOpenIntervalInMbDefault creates a FindConfigSstablePreemptiveOpenIntervalInMbDefault with default headers values

func (*FindConfigSstablePreemptiveOpenIntervalInMbDefault) Code ¶

Code gets the status code for the find config sstable preemptive open interval in mb default response

func (*FindConfigSstablePreemptiveOpenIntervalInMbDefault) Error ¶

func (*FindConfigSstablePreemptiveOpenIntervalInMbDefault) GetPayload ¶

type FindConfigSstablePreemptiveOpenIntervalInMbOK ¶

type FindConfigSstablePreemptiveOpenIntervalInMbOK struct {
	Payload int64
}

FindConfigSstablePreemptiveOpenIntervalInMbOK handles this case with default header values.

Config value

func NewFindConfigSstablePreemptiveOpenIntervalInMbOK ¶

func NewFindConfigSstablePreemptiveOpenIntervalInMbOK() *FindConfigSstablePreemptiveOpenIntervalInMbOK

NewFindConfigSstablePreemptiveOpenIntervalInMbOK creates a FindConfigSstablePreemptiveOpenIntervalInMbOK with default headers values

func (*FindConfigSstablePreemptiveOpenIntervalInMbOK) GetPayload ¶

type FindConfigSstablePreemptiveOpenIntervalInMbParams ¶

type FindConfigSstablePreemptiveOpenIntervalInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigSstablePreemptiveOpenIntervalInMbParams contains all the parameters to send to the API endpoint for the find config sstable preemptive open interval in mb operation typically these are written to a http.Request

func NewFindConfigSstablePreemptiveOpenIntervalInMbParams ¶

func NewFindConfigSstablePreemptiveOpenIntervalInMbParams() *FindConfigSstablePreemptiveOpenIntervalInMbParams

NewFindConfigSstablePreemptiveOpenIntervalInMbParams creates a new FindConfigSstablePreemptiveOpenIntervalInMbParams object with the default values initialized.

func NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithContext ¶

func NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithContext(ctx context.Context) *FindConfigSstablePreemptiveOpenIntervalInMbParams

NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithContext creates a new FindConfigSstablePreemptiveOpenIntervalInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithHTTPClient ¶

func NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithHTTPClient(client *http.Client) *FindConfigSstablePreemptiveOpenIntervalInMbParams

NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithHTTPClient creates a new FindConfigSstablePreemptiveOpenIntervalInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithTimeout ¶

func NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithTimeout(timeout time.Duration) *FindConfigSstablePreemptiveOpenIntervalInMbParams

NewFindConfigSstablePreemptiveOpenIntervalInMbParamsWithTimeout creates a new FindConfigSstablePreemptiveOpenIntervalInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigSstablePreemptiveOpenIntervalInMbParams) SetContext ¶

SetContext adds the context to the find config sstable preemptive open interval in mb params

func (*FindConfigSstablePreemptiveOpenIntervalInMbParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config sstable preemptive open interval in mb params

func (*FindConfigSstablePreemptiveOpenIntervalInMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config sstable preemptive open interval in mb params

func (*FindConfigSstablePreemptiveOpenIntervalInMbParams) WithContext ¶

WithContext adds the context to the find config sstable preemptive open interval in mb params

func (*FindConfigSstablePreemptiveOpenIntervalInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config sstable preemptive open interval in mb params

func (*FindConfigSstablePreemptiveOpenIntervalInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config sstable preemptive open interval in mb params

func (*FindConfigSstablePreemptiveOpenIntervalInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigSstablePreemptiveOpenIntervalInMbReader ¶

type FindConfigSstablePreemptiveOpenIntervalInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigSstablePreemptiveOpenIntervalInMbReader is a Reader for the FindConfigSstablePreemptiveOpenIntervalInMb structure.

func (*FindConfigSstablePreemptiveOpenIntervalInMbReader) ReadResponse ¶

func (o *FindConfigSstablePreemptiveOpenIntervalInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigSstableSummaryRatioDefault ¶

type FindConfigSstableSummaryRatioDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigSstableSummaryRatioDefault handles this case with default header values.

unexpected error

func NewFindConfigSstableSummaryRatioDefault ¶

func NewFindConfigSstableSummaryRatioDefault(code int) *FindConfigSstableSummaryRatioDefault

NewFindConfigSstableSummaryRatioDefault creates a FindConfigSstableSummaryRatioDefault with default headers values

func (*FindConfigSstableSummaryRatioDefault) Code ¶

Code gets the status code for the find config sstable summary ratio default response

func (*FindConfigSstableSummaryRatioDefault) Error ¶

func (*FindConfigSstableSummaryRatioDefault) GetPayload ¶

type FindConfigSstableSummaryRatioOK ¶

type FindConfigSstableSummaryRatioOK struct {
	Payload float64
}

FindConfigSstableSummaryRatioOK handles this case with default header values.

Config value

func NewFindConfigSstableSummaryRatioOK ¶

func NewFindConfigSstableSummaryRatioOK() *FindConfigSstableSummaryRatioOK

NewFindConfigSstableSummaryRatioOK creates a FindConfigSstableSummaryRatioOK with default headers values

func (*FindConfigSstableSummaryRatioOK) GetPayload ¶

func (o *FindConfigSstableSummaryRatioOK) GetPayload() float64

type FindConfigSstableSummaryRatioParams ¶

type FindConfigSstableSummaryRatioParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigSstableSummaryRatioParams contains all the parameters to send to the API endpoint for the find config sstable summary ratio operation typically these are written to a http.Request

func NewFindConfigSstableSummaryRatioParams ¶

func NewFindConfigSstableSummaryRatioParams() *FindConfigSstableSummaryRatioParams

NewFindConfigSstableSummaryRatioParams creates a new FindConfigSstableSummaryRatioParams object with the default values initialized.

func NewFindConfigSstableSummaryRatioParamsWithContext ¶

func NewFindConfigSstableSummaryRatioParamsWithContext(ctx context.Context) *FindConfigSstableSummaryRatioParams

NewFindConfigSstableSummaryRatioParamsWithContext creates a new FindConfigSstableSummaryRatioParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigSstableSummaryRatioParamsWithHTTPClient ¶

func NewFindConfigSstableSummaryRatioParamsWithHTTPClient(client *http.Client) *FindConfigSstableSummaryRatioParams

NewFindConfigSstableSummaryRatioParamsWithHTTPClient creates a new FindConfigSstableSummaryRatioParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigSstableSummaryRatioParamsWithTimeout ¶

func NewFindConfigSstableSummaryRatioParamsWithTimeout(timeout time.Duration) *FindConfigSstableSummaryRatioParams

NewFindConfigSstableSummaryRatioParamsWithTimeout creates a new FindConfigSstableSummaryRatioParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigSstableSummaryRatioParams) SetContext ¶

SetContext adds the context to the find config sstable summary ratio params

func (*FindConfigSstableSummaryRatioParams) SetHTTPClient ¶

func (o *FindConfigSstableSummaryRatioParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config sstable summary ratio params

func (*FindConfigSstableSummaryRatioParams) SetTimeout ¶

func (o *FindConfigSstableSummaryRatioParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config sstable summary ratio params

func (*FindConfigSstableSummaryRatioParams) WithContext ¶

WithContext adds the context to the find config sstable summary ratio params

func (*FindConfigSstableSummaryRatioParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config sstable summary ratio params

func (*FindConfigSstableSummaryRatioParams) WithTimeout ¶

WithTimeout adds the timeout to the find config sstable summary ratio params

func (*FindConfigSstableSummaryRatioParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigSstableSummaryRatioReader ¶

type FindConfigSstableSummaryRatioReader struct {
	// contains filtered or unexported fields
}

FindConfigSstableSummaryRatioReader is a Reader for the FindConfigSstableSummaryRatio structure.

func (*FindConfigSstableSummaryRatioReader) ReadResponse ¶

func (o *FindConfigSstableSummaryRatioReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigStartNativeTransportDefault ¶

type FindConfigStartNativeTransportDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigStartNativeTransportDefault handles this case with default header values.

unexpected error

func NewFindConfigStartNativeTransportDefault ¶

func NewFindConfigStartNativeTransportDefault(code int) *FindConfigStartNativeTransportDefault

NewFindConfigStartNativeTransportDefault creates a FindConfigStartNativeTransportDefault with default headers values

func (*FindConfigStartNativeTransportDefault) Code ¶

Code gets the status code for the find config start native transport default response

func (*FindConfigStartNativeTransportDefault) Error ¶

func (*FindConfigStartNativeTransportDefault) GetPayload ¶

type FindConfigStartNativeTransportOK ¶

type FindConfigStartNativeTransportOK struct {
	Payload bool
}

FindConfigStartNativeTransportOK handles this case with default header values.

Config value

func NewFindConfigStartNativeTransportOK ¶

func NewFindConfigStartNativeTransportOK() *FindConfigStartNativeTransportOK

NewFindConfigStartNativeTransportOK creates a FindConfigStartNativeTransportOK with default headers values

func (*FindConfigStartNativeTransportOK) GetPayload ¶

func (o *FindConfigStartNativeTransportOK) GetPayload() bool

type FindConfigStartNativeTransportParams ¶

type FindConfigStartNativeTransportParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigStartNativeTransportParams contains all the parameters to send to the API endpoint for the find config start native transport operation typically these are written to a http.Request

func NewFindConfigStartNativeTransportParams ¶

func NewFindConfigStartNativeTransportParams() *FindConfigStartNativeTransportParams

NewFindConfigStartNativeTransportParams creates a new FindConfigStartNativeTransportParams object with the default values initialized.

func NewFindConfigStartNativeTransportParamsWithContext ¶

func NewFindConfigStartNativeTransportParamsWithContext(ctx context.Context) *FindConfigStartNativeTransportParams

NewFindConfigStartNativeTransportParamsWithContext creates a new FindConfigStartNativeTransportParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigStartNativeTransportParamsWithHTTPClient ¶

func NewFindConfigStartNativeTransportParamsWithHTTPClient(client *http.Client) *FindConfigStartNativeTransportParams

NewFindConfigStartNativeTransportParamsWithHTTPClient creates a new FindConfigStartNativeTransportParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigStartNativeTransportParamsWithTimeout ¶

func NewFindConfigStartNativeTransportParamsWithTimeout(timeout time.Duration) *FindConfigStartNativeTransportParams

NewFindConfigStartNativeTransportParamsWithTimeout creates a new FindConfigStartNativeTransportParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigStartNativeTransportParams) SetContext ¶

SetContext adds the context to the find config start native transport params

func (*FindConfigStartNativeTransportParams) SetHTTPClient ¶

func (o *FindConfigStartNativeTransportParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config start native transport params

func (*FindConfigStartNativeTransportParams) SetTimeout ¶

func (o *FindConfigStartNativeTransportParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config start native transport params

func (*FindConfigStartNativeTransportParams) WithContext ¶

WithContext adds the context to the find config start native transport params

func (*FindConfigStartNativeTransportParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config start native transport params

func (*FindConfigStartNativeTransportParams) WithTimeout ¶

WithTimeout adds the timeout to the find config start native transport params

func (*FindConfigStartNativeTransportParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigStartNativeTransportReader ¶

type FindConfigStartNativeTransportReader struct {
	// contains filtered or unexported fields
}

FindConfigStartNativeTransportReader is a Reader for the FindConfigStartNativeTransport structure.

func (*FindConfigStartNativeTransportReader) ReadResponse ¶

func (o *FindConfigStartNativeTransportReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigStartRPCDefault ¶

type FindConfigStartRPCDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigStartRPCDefault handles this case with default header values.

unexpected error

func NewFindConfigStartRPCDefault ¶

func NewFindConfigStartRPCDefault(code int) *FindConfigStartRPCDefault

NewFindConfigStartRPCDefault creates a FindConfigStartRPCDefault with default headers values

func (*FindConfigStartRPCDefault) Code ¶

func (o *FindConfigStartRPCDefault) Code() int

Code gets the status code for the find config start rpc default response

func (*FindConfigStartRPCDefault) Error ¶

func (o *FindConfigStartRPCDefault) Error() string

func (*FindConfigStartRPCDefault) GetPayload ¶

func (o *FindConfigStartRPCDefault) GetPayload() *models.ErrorModel

type FindConfigStartRPCOK ¶

type FindConfigStartRPCOK struct {
	Payload bool
}

FindConfigStartRPCOK handles this case with default header values.

Config value

func NewFindConfigStartRPCOK ¶

func NewFindConfigStartRPCOK() *FindConfigStartRPCOK

NewFindConfigStartRPCOK creates a FindConfigStartRPCOK with default headers values

func (*FindConfigStartRPCOK) GetPayload ¶

func (o *FindConfigStartRPCOK) GetPayload() bool

type FindConfigStartRPCParams ¶

type FindConfigStartRPCParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigStartRPCParams contains all the parameters to send to the API endpoint for the find config start rpc operation typically these are written to a http.Request

func NewFindConfigStartRPCParams ¶

func NewFindConfigStartRPCParams() *FindConfigStartRPCParams

NewFindConfigStartRPCParams creates a new FindConfigStartRPCParams object with the default values initialized.

func NewFindConfigStartRPCParamsWithContext ¶

func NewFindConfigStartRPCParamsWithContext(ctx context.Context) *FindConfigStartRPCParams

NewFindConfigStartRPCParamsWithContext creates a new FindConfigStartRPCParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigStartRPCParamsWithHTTPClient ¶

func NewFindConfigStartRPCParamsWithHTTPClient(client *http.Client) *FindConfigStartRPCParams

NewFindConfigStartRPCParamsWithHTTPClient creates a new FindConfigStartRPCParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigStartRPCParamsWithTimeout ¶

func NewFindConfigStartRPCParamsWithTimeout(timeout time.Duration) *FindConfigStartRPCParams

NewFindConfigStartRPCParamsWithTimeout creates a new FindConfigStartRPCParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigStartRPCParams) SetContext ¶

func (o *FindConfigStartRPCParams) SetContext(ctx context.Context)

SetContext adds the context to the find config start rpc params

func (*FindConfigStartRPCParams) SetHTTPClient ¶

func (o *FindConfigStartRPCParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config start rpc params

func (*FindConfigStartRPCParams) SetTimeout ¶

func (o *FindConfigStartRPCParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config start rpc params

func (*FindConfigStartRPCParams) WithContext ¶

WithContext adds the context to the find config start rpc params

func (*FindConfigStartRPCParams) WithHTTPClient ¶

func (o *FindConfigStartRPCParams) WithHTTPClient(client *http.Client) *FindConfigStartRPCParams

WithHTTPClient adds the HTTPClient to the find config start rpc params

func (*FindConfigStartRPCParams) WithTimeout ¶

WithTimeout adds the timeout to the find config start rpc params

func (*FindConfigStartRPCParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigStartRPCReader ¶

type FindConfigStartRPCReader struct {
	// contains filtered or unexported fields
}

FindConfigStartRPCReader is a Reader for the FindConfigStartRPC structure.

func (*FindConfigStartRPCReader) ReadResponse ¶

func (o *FindConfigStartRPCReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigStoragePortDefault ¶

type FindConfigStoragePortDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigStoragePortDefault handles this case with default header values.

unexpected error

func NewFindConfigStoragePortDefault ¶

func NewFindConfigStoragePortDefault(code int) *FindConfigStoragePortDefault

NewFindConfigStoragePortDefault creates a FindConfigStoragePortDefault with default headers values

func (*FindConfigStoragePortDefault) Code ¶

Code gets the status code for the find config storage port default response

func (*FindConfigStoragePortDefault) Error ¶

func (*FindConfigStoragePortDefault) GetPayload ¶

type FindConfigStoragePortOK ¶

type FindConfigStoragePortOK struct {
	Payload int64
}

FindConfigStoragePortOK handles this case with default header values.

Config value

func NewFindConfigStoragePortOK ¶

func NewFindConfigStoragePortOK() *FindConfigStoragePortOK

NewFindConfigStoragePortOK creates a FindConfigStoragePortOK with default headers values

func (*FindConfigStoragePortOK) GetPayload ¶

func (o *FindConfigStoragePortOK) GetPayload() int64

type FindConfigStoragePortParams ¶

type FindConfigStoragePortParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigStoragePortParams contains all the parameters to send to the API endpoint for the find config storage port operation typically these are written to a http.Request

func NewFindConfigStoragePortParams ¶

func NewFindConfigStoragePortParams() *FindConfigStoragePortParams

NewFindConfigStoragePortParams creates a new FindConfigStoragePortParams object with the default values initialized.

func NewFindConfigStoragePortParamsWithContext ¶

func NewFindConfigStoragePortParamsWithContext(ctx context.Context) *FindConfigStoragePortParams

NewFindConfigStoragePortParamsWithContext creates a new FindConfigStoragePortParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigStoragePortParamsWithHTTPClient ¶

func NewFindConfigStoragePortParamsWithHTTPClient(client *http.Client) *FindConfigStoragePortParams

NewFindConfigStoragePortParamsWithHTTPClient creates a new FindConfigStoragePortParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigStoragePortParamsWithTimeout ¶

func NewFindConfigStoragePortParamsWithTimeout(timeout time.Duration) *FindConfigStoragePortParams

NewFindConfigStoragePortParamsWithTimeout creates a new FindConfigStoragePortParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigStoragePortParams) SetContext ¶

func (o *FindConfigStoragePortParams) SetContext(ctx context.Context)

SetContext adds the context to the find config storage port params

func (*FindConfigStoragePortParams) SetHTTPClient ¶

func (o *FindConfigStoragePortParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config storage port params

func (*FindConfigStoragePortParams) SetTimeout ¶

func (o *FindConfigStoragePortParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config storage port params

func (*FindConfigStoragePortParams) WithContext ¶

WithContext adds the context to the find config storage port params

func (*FindConfigStoragePortParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config storage port params

func (*FindConfigStoragePortParams) WithTimeout ¶

WithTimeout adds the timeout to the find config storage port params

func (*FindConfigStoragePortParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigStoragePortReader ¶

type FindConfigStoragePortReader struct {
	// contains filtered or unexported fields
}

FindConfigStoragePortReader is a Reader for the FindConfigStoragePort structure.

func (*FindConfigStoragePortReader) ReadResponse ¶

func (o *FindConfigStoragePortReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigStreamThroughputOutboundMegabitsPerSecDefault ¶

type FindConfigStreamThroughputOutboundMegabitsPerSecDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigStreamThroughputOutboundMegabitsPerSecDefault handles this case with default header values.

unexpected error

func NewFindConfigStreamThroughputOutboundMegabitsPerSecDefault ¶

func NewFindConfigStreamThroughputOutboundMegabitsPerSecDefault(code int) *FindConfigStreamThroughputOutboundMegabitsPerSecDefault

NewFindConfigStreamThroughputOutboundMegabitsPerSecDefault creates a FindConfigStreamThroughputOutboundMegabitsPerSecDefault with default headers values

func (*FindConfigStreamThroughputOutboundMegabitsPerSecDefault) Code ¶

Code gets the status code for the find config stream throughput outbound megabits per sec default response

func (*FindConfigStreamThroughputOutboundMegabitsPerSecDefault) Error ¶

func (*FindConfigStreamThroughputOutboundMegabitsPerSecDefault) GetPayload ¶

type FindConfigStreamThroughputOutboundMegabitsPerSecOK ¶

type FindConfigStreamThroughputOutboundMegabitsPerSecOK struct {
	Payload int64
}

FindConfigStreamThroughputOutboundMegabitsPerSecOK handles this case with default header values.

Config value

func NewFindConfigStreamThroughputOutboundMegabitsPerSecOK ¶

func NewFindConfigStreamThroughputOutboundMegabitsPerSecOK() *FindConfigStreamThroughputOutboundMegabitsPerSecOK

NewFindConfigStreamThroughputOutboundMegabitsPerSecOK creates a FindConfigStreamThroughputOutboundMegabitsPerSecOK with default headers values

func (*FindConfigStreamThroughputOutboundMegabitsPerSecOK) GetPayload ¶

type FindConfigStreamThroughputOutboundMegabitsPerSecParams ¶

type FindConfigStreamThroughputOutboundMegabitsPerSecParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigStreamThroughputOutboundMegabitsPerSecParams contains all the parameters to send to the API endpoint for the find config stream throughput outbound megabits per sec operation typically these are written to a http.Request

func NewFindConfigStreamThroughputOutboundMegabitsPerSecParams ¶

func NewFindConfigStreamThroughputOutboundMegabitsPerSecParams() *FindConfigStreamThroughputOutboundMegabitsPerSecParams

NewFindConfigStreamThroughputOutboundMegabitsPerSecParams creates a new FindConfigStreamThroughputOutboundMegabitsPerSecParams object with the default values initialized.

func NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithContext ¶

func NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithContext(ctx context.Context) *FindConfigStreamThroughputOutboundMegabitsPerSecParams

NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithContext creates a new FindConfigStreamThroughputOutboundMegabitsPerSecParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithHTTPClient ¶

func NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithHTTPClient(client *http.Client) *FindConfigStreamThroughputOutboundMegabitsPerSecParams

NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithHTTPClient creates a new FindConfigStreamThroughputOutboundMegabitsPerSecParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithTimeout ¶

func NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithTimeout(timeout time.Duration) *FindConfigStreamThroughputOutboundMegabitsPerSecParams

NewFindConfigStreamThroughputOutboundMegabitsPerSecParamsWithTimeout creates a new FindConfigStreamThroughputOutboundMegabitsPerSecParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigStreamThroughputOutboundMegabitsPerSecParams) SetContext ¶

SetContext adds the context to the find config stream throughput outbound megabits per sec params

func (*FindConfigStreamThroughputOutboundMegabitsPerSecParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config stream throughput outbound megabits per sec params

func (*FindConfigStreamThroughputOutboundMegabitsPerSecParams) SetTimeout ¶

SetTimeout adds the timeout to the find config stream throughput outbound megabits per sec params

func (*FindConfigStreamThroughputOutboundMegabitsPerSecParams) WithContext ¶

WithContext adds the context to the find config stream throughput outbound megabits per sec params

func (*FindConfigStreamThroughputOutboundMegabitsPerSecParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config stream throughput outbound megabits per sec params

func (*FindConfigStreamThroughputOutboundMegabitsPerSecParams) WithTimeout ¶

WithTimeout adds the timeout to the find config stream throughput outbound megabits per sec params

func (*FindConfigStreamThroughputOutboundMegabitsPerSecParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigStreamThroughputOutboundMegabitsPerSecReader ¶

type FindConfigStreamThroughputOutboundMegabitsPerSecReader struct {
	// contains filtered or unexported fields
}

FindConfigStreamThroughputOutboundMegabitsPerSecReader is a Reader for the FindConfigStreamThroughputOutboundMegabitsPerSec structure.

func (*FindConfigStreamThroughputOutboundMegabitsPerSecReader) ReadResponse ¶

func (o *FindConfigStreamThroughputOutboundMegabitsPerSecReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigStreamingSocketTimeoutInMsDefault ¶

type FindConfigStreamingSocketTimeoutInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigStreamingSocketTimeoutInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigStreamingSocketTimeoutInMsDefault ¶

func NewFindConfigStreamingSocketTimeoutInMsDefault(code int) *FindConfigStreamingSocketTimeoutInMsDefault

NewFindConfigStreamingSocketTimeoutInMsDefault creates a FindConfigStreamingSocketTimeoutInMsDefault with default headers values

func (*FindConfigStreamingSocketTimeoutInMsDefault) Code ¶

Code gets the status code for the find config streaming socket timeout in ms default response

func (*FindConfigStreamingSocketTimeoutInMsDefault) Error ¶

func (*FindConfigStreamingSocketTimeoutInMsDefault) GetPayload ¶

type FindConfigStreamingSocketTimeoutInMsOK ¶

type FindConfigStreamingSocketTimeoutInMsOK struct {
	Payload int64
}

FindConfigStreamingSocketTimeoutInMsOK handles this case with default header values.

Config value

func NewFindConfigStreamingSocketTimeoutInMsOK ¶

func NewFindConfigStreamingSocketTimeoutInMsOK() *FindConfigStreamingSocketTimeoutInMsOK

NewFindConfigStreamingSocketTimeoutInMsOK creates a FindConfigStreamingSocketTimeoutInMsOK with default headers values

func (*FindConfigStreamingSocketTimeoutInMsOK) GetPayload ¶

type FindConfigStreamingSocketTimeoutInMsParams ¶

type FindConfigStreamingSocketTimeoutInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigStreamingSocketTimeoutInMsParams contains all the parameters to send to the API endpoint for the find config streaming socket timeout in ms operation typically these are written to a http.Request

func NewFindConfigStreamingSocketTimeoutInMsParams ¶

func NewFindConfigStreamingSocketTimeoutInMsParams() *FindConfigStreamingSocketTimeoutInMsParams

NewFindConfigStreamingSocketTimeoutInMsParams creates a new FindConfigStreamingSocketTimeoutInMsParams object with the default values initialized.

func NewFindConfigStreamingSocketTimeoutInMsParamsWithContext ¶

func NewFindConfigStreamingSocketTimeoutInMsParamsWithContext(ctx context.Context) *FindConfigStreamingSocketTimeoutInMsParams

NewFindConfigStreamingSocketTimeoutInMsParamsWithContext creates a new FindConfigStreamingSocketTimeoutInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigStreamingSocketTimeoutInMsParamsWithHTTPClient ¶

func NewFindConfigStreamingSocketTimeoutInMsParamsWithHTTPClient(client *http.Client) *FindConfigStreamingSocketTimeoutInMsParams

NewFindConfigStreamingSocketTimeoutInMsParamsWithHTTPClient creates a new FindConfigStreamingSocketTimeoutInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigStreamingSocketTimeoutInMsParamsWithTimeout ¶

func NewFindConfigStreamingSocketTimeoutInMsParamsWithTimeout(timeout time.Duration) *FindConfigStreamingSocketTimeoutInMsParams

NewFindConfigStreamingSocketTimeoutInMsParamsWithTimeout creates a new FindConfigStreamingSocketTimeoutInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigStreamingSocketTimeoutInMsParams) SetContext ¶

SetContext adds the context to the find config streaming socket timeout in ms params

func (*FindConfigStreamingSocketTimeoutInMsParams) SetHTTPClient ¶

func (o *FindConfigStreamingSocketTimeoutInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config streaming socket timeout in ms params

func (*FindConfigStreamingSocketTimeoutInMsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config streaming socket timeout in ms params

func (*FindConfigStreamingSocketTimeoutInMsParams) WithContext ¶

WithContext adds the context to the find config streaming socket timeout in ms params

func (*FindConfigStreamingSocketTimeoutInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config streaming socket timeout in ms params

func (*FindConfigStreamingSocketTimeoutInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config streaming socket timeout in ms params

func (*FindConfigStreamingSocketTimeoutInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigStreamingSocketTimeoutInMsReader ¶

type FindConfigStreamingSocketTimeoutInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigStreamingSocketTimeoutInMsReader is a Reader for the FindConfigStreamingSocketTimeoutInMs structure.

func (*FindConfigStreamingSocketTimeoutInMsReader) ReadResponse ¶

func (o *FindConfigStreamingSocketTimeoutInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigThriftFramedTransportSizeInMbDefault ¶

type FindConfigThriftFramedTransportSizeInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigThriftFramedTransportSizeInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigThriftFramedTransportSizeInMbDefault ¶

func NewFindConfigThriftFramedTransportSizeInMbDefault(code int) *FindConfigThriftFramedTransportSizeInMbDefault

NewFindConfigThriftFramedTransportSizeInMbDefault creates a FindConfigThriftFramedTransportSizeInMbDefault with default headers values

func (*FindConfigThriftFramedTransportSizeInMbDefault) Code ¶

Code gets the status code for the find config thrift framed transport size in mb default response

func (*FindConfigThriftFramedTransportSizeInMbDefault) Error ¶

func (*FindConfigThriftFramedTransportSizeInMbDefault) GetPayload ¶

type FindConfigThriftFramedTransportSizeInMbOK ¶

type FindConfigThriftFramedTransportSizeInMbOK struct {
	Payload int64
}

FindConfigThriftFramedTransportSizeInMbOK handles this case with default header values.

Config value

func NewFindConfigThriftFramedTransportSizeInMbOK ¶

func NewFindConfigThriftFramedTransportSizeInMbOK() *FindConfigThriftFramedTransportSizeInMbOK

NewFindConfigThriftFramedTransportSizeInMbOK creates a FindConfigThriftFramedTransportSizeInMbOK with default headers values

func (*FindConfigThriftFramedTransportSizeInMbOK) GetPayload ¶

type FindConfigThriftFramedTransportSizeInMbParams ¶

type FindConfigThriftFramedTransportSizeInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigThriftFramedTransportSizeInMbParams contains all the parameters to send to the API endpoint for the find config thrift framed transport size in mb operation typically these are written to a http.Request

func NewFindConfigThriftFramedTransportSizeInMbParams ¶

func NewFindConfigThriftFramedTransportSizeInMbParams() *FindConfigThriftFramedTransportSizeInMbParams

NewFindConfigThriftFramedTransportSizeInMbParams creates a new FindConfigThriftFramedTransportSizeInMbParams object with the default values initialized.

func NewFindConfigThriftFramedTransportSizeInMbParamsWithContext ¶

func NewFindConfigThriftFramedTransportSizeInMbParamsWithContext(ctx context.Context) *FindConfigThriftFramedTransportSizeInMbParams

NewFindConfigThriftFramedTransportSizeInMbParamsWithContext creates a new FindConfigThriftFramedTransportSizeInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigThriftFramedTransportSizeInMbParamsWithHTTPClient ¶

func NewFindConfigThriftFramedTransportSizeInMbParamsWithHTTPClient(client *http.Client) *FindConfigThriftFramedTransportSizeInMbParams

NewFindConfigThriftFramedTransportSizeInMbParamsWithHTTPClient creates a new FindConfigThriftFramedTransportSizeInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigThriftFramedTransportSizeInMbParamsWithTimeout ¶

func NewFindConfigThriftFramedTransportSizeInMbParamsWithTimeout(timeout time.Duration) *FindConfigThriftFramedTransportSizeInMbParams

NewFindConfigThriftFramedTransportSizeInMbParamsWithTimeout creates a new FindConfigThriftFramedTransportSizeInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigThriftFramedTransportSizeInMbParams) SetContext ¶

SetContext adds the context to the find config thrift framed transport size in mb params

func (*FindConfigThriftFramedTransportSizeInMbParams) SetHTTPClient ¶

func (o *FindConfigThriftFramedTransportSizeInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config thrift framed transport size in mb params

func (*FindConfigThriftFramedTransportSizeInMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config thrift framed transport size in mb params

func (*FindConfigThriftFramedTransportSizeInMbParams) WithContext ¶

WithContext adds the context to the find config thrift framed transport size in mb params

func (*FindConfigThriftFramedTransportSizeInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config thrift framed transport size in mb params

func (*FindConfigThriftFramedTransportSizeInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config thrift framed transport size in mb params

func (*FindConfigThriftFramedTransportSizeInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigThriftFramedTransportSizeInMbReader ¶

type FindConfigThriftFramedTransportSizeInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigThriftFramedTransportSizeInMbReader is a Reader for the FindConfigThriftFramedTransportSizeInMb structure.

func (*FindConfigThriftFramedTransportSizeInMbReader) ReadResponse ¶

func (o *FindConfigThriftFramedTransportSizeInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigThriftMaxMessageLengthInMbDefault ¶

type FindConfigThriftMaxMessageLengthInMbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigThriftMaxMessageLengthInMbDefault handles this case with default header values.

unexpected error

func NewFindConfigThriftMaxMessageLengthInMbDefault ¶

func NewFindConfigThriftMaxMessageLengthInMbDefault(code int) *FindConfigThriftMaxMessageLengthInMbDefault

NewFindConfigThriftMaxMessageLengthInMbDefault creates a FindConfigThriftMaxMessageLengthInMbDefault with default headers values

func (*FindConfigThriftMaxMessageLengthInMbDefault) Code ¶

Code gets the status code for the find config thrift max message length in mb default response

func (*FindConfigThriftMaxMessageLengthInMbDefault) Error ¶

func (*FindConfigThriftMaxMessageLengthInMbDefault) GetPayload ¶

type FindConfigThriftMaxMessageLengthInMbOK ¶

type FindConfigThriftMaxMessageLengthInMbOK struct {
	Payload int64
}

FindConfigThriftMaxMessageLengthInMbOK handles this case with default header values.

Config value

func NewFindConfigThriftMaxMessageLengthInMbOK ¶

func NewFindConfigThriftMaxMessageLengthInMbOK() *FindConfigThriftMaxMessageLengthInMbOK

NewFindConfigThriftMaxMessageLengthInMbOK creates a FindConfigThriftMaxMessageLengthInMbOK with default headers values

func (*FindConfigThriftMaxMessageLengthInMbOK) GetPayload ¶

type FindConfigThriftMaxMessageLengthInMbParams ¶

type FindConfigThriftMaxMessageLengthInMbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigThriftMaxMessageLengthInMbParams contains all the parameters to send to the API endpoint for the find config thrift max message length in mb operation typically these are written to a http.Request

func NewFindConfigThriftMaxMessageLengthInMbParams ¶

func NewFindConfigThriftMaxMessageLengthInMbParams() *FindConfigThriftMaxMessageLengthInMbParams

NewFindConfigThriftMaxMessageLengthInMbParams creates a new FindConfigThriftMaxMessageLengthInMbParams object with the default values initialized.

func NewFindConfigThriftMaxMessageLengthInMbParamsWithContext ¶

func NewFindConfigThriftMaxMessageLengthInMbParamsWithContext(ctx context.Context) *FindConfigThriftMaxMessageLengthInMbParams

NewFindConfigThriftMaxMessageLengthInMbParamsWithContext creates a new FindConfigThriftMaxMessageLengthInMbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigThriftMaxMessageLengthInMbParamsWithHTTPClient ¶

func NewFindConfigThriftMaxMessageLengthInMbParamsWithHTTPClient(client *http.Client) *FindConfigThriftMaxMessageLengthInMbParams

NewFindConfigThriftMaxMessageLengthInMbParamsWithHTTPClient creates a new FindConfigThriftMaxMessageLengthInMbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigThriftMaxMessageLengthInMbParamsWithTimeout ¶

func NewFindConfigThriftMaxMessageLengthInMbParamsWithTimeout(timeout time.Duration) *FindConfigThriftMaxMessageLengthInMbParams

NewFindConfigThriftMaxMessageLengthInMbParamsWithTimeout creates a new FindConfigThriftMaxMessageLengthInMbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigThriftMaxMessageLengthInMbParams) SetContext ¶

SetContext adds the context to the find config thrift max message length in mb params

func (*FindConfigThriftMaxMessageLengthInMbParams) SetHTTPClient ¶

func (o *FindConfigThriftMaxMessageLengthInMbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config thrift max message length in mb params

func (*FindConfigThriftMaxMessageLengthInMbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config thrift max message length in mb params

func (*FindConfigThriftMaxMessageLengthInMbParams) WithContext ¶

WithContext adds the context to the find config thrift max message length in mb params

func (*FindConfigThriftMaxMessageLengthInMbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config thrift max message length in mb params

func (*FindConfigThriftMaxMessageLengthInMbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config thrift max message length in mb params

func (*FindConfigThriftMaxMessageLengthInMbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigThriftMaxMessageLengthInMbReader ¶

type FindConfigThriftMaxMessageLengthInMbReader struct {
	// contains filtered or unexported fields
}

FindConfigThriftMaxMessageLengthInMbReader is a Reader for the FindConfigThriftMaxMessageLengthInMb structure.

func (*FindConfigThriftMaxMessageLengthInMbReader) ReadResponse ¶

func (o *FindConfigThriftMaxMessageLengthInMbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigTombstoneFailureThresholdDefault ¶

type FindConfigTombstoneFailureThresholdDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigTombstoneFailureThresholdDefault handles this case with default header values.

unexpected error

func NewFindConfigTombstoneFailureThresholdDefault ¶

func NewFindConfigTombstoneFailureThresholdDefault(code int) *FindConfigTombstoneFailureThresholdDefault

NewFindConfigTombstoneFailureThresholdDefault creates a FindConfigTombstoneFailureThresholdDefault with default headers values

func (*FindConfigTombstoneFailureThresholdDefault) Code ¶

Code gets the status code for the find config tombstone failure threshold default response

func (*FindConfigTombstoneFailureThresholdDefault) Error ¶

func (*FindConfigTombstoneFailureThresholdDefault) GetPayload ¶

type FindConfigTombstoneFailureThresholdOK ¶

type FindConfigTombstoneFailureThresholdOK struct {
	Payload int64
}

FindConfigTombstoneFailureThresholdOK handles this case with default header values.

Config value

func NewFindConfigTombstoneFailureThresholdOK ¶

func NewFindConfigTombstoneFailureThresholdOK() *FindConfigTombstoneFailureThresholdOK

NewFindConfigTombstoneFailureThresholdOK creates a FindConfigTombstoneFailureThresholdOK with default headers values

func (*FindConfigTombstoneFailureThresholdOK) GetPayload ¶

type FindConfigTombstoneFailureThresholdParams ¶

type FindConfigTombstoneFailureThresholdParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigTombstoneFailureThresholdParams contains all the parameters to send to the API endpoint for the find config tombstone failure threshold operation typically these are written to a http.Request

func NewFindConfigTombstoneFailureThresholdParams ¶

func NewFindConfigTombstoneFailureThresholdParams() *FindConfigTombstoneFailureThresholdParams

NewFindConfigTombstoneFailureThresholdParams creates a new FindConfigTombstoneFailureThresholdParams object with the default values initialized.

func NewFindConfigTombstoneFailureThresholdParamsWithContext ¶

func NewFindConfigTombstoneFailureThresholdParamsWithContext(ctx context.Context) *FindConfigTombstoneFailureThresholdParams

NewFindConfigTombstoneFailureThresholdParamsWithContext creates a new FindConfigTombstoneFailureThresholdParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigTombstoneFailureThresholdParamsWithHTTPClient ¶

func NewFindConfigTombstoneFailureThresholdParamsWithHTTPClient(client *http.Client) *FindConfigTombstoneFailureThresholdParams

NewFindConfigTombstoneFailureThresholdParamsWithHTTPClient creates a new FindConfigTombstoneFailureThresholdParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigTombstoneFailureThresholdParamsWithTimeout ¶

func NewFindConfigTombstoneFailureThresholdParamsWithTimeout(timeout time.Duration) *FindConfigTombstoneFailureThresholdParams

NewFindConfigTombstoneFailureThresholdParamsWithTimeout creates a new FindConfigTombstoneFailureThresholdParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigTombstoneFailureThresholdParams) SetContext ¶

SetContext adds the context to the find config tombstone failure threshold params

func (*FindConfigTombstoneFailureThresholdParams) SetHTTPClient ¶

func (o *FindConfigTombstoneFailureThresholdParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config tombstone failure threshold params

func (*FindConfigTombstoneFailureThresholdParams) SetTimeout ¶

SetTimeout adds the timeout to the find config tombstone failure threshold params

func (*FindConfigTombstoneFailureThresholdParams) WithContext ¶

WithContext adds the context to the find config tombstone failure threshold params

func (*FindConfigTombstoneFailureThresholdParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config tombstone failure threshold params

func (*FindConfigTombstoneFailureThresholdParams) WithTimeout ¶

WithTimeout adds the timeout to the find config tombstone failure threshold params

func (*FindConfigTombstoneFailureThresholdParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigTombstoneFailureThresholdReader ¶

type FindConfigTombstoneFailureThresholdReader struct {
	// contains filtered or unexported fields
}

FindConfigTombstoneFailureThresholdReader is a Reader for the FindConfigTombstoneFailureThreshold structure.

func (*FindConfigTombstoneFailureThresholdReader) ReadResponse ¶

func (o *FindConfigTombstoneFailureThresholdReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigTombstoneWarnThresholdDefault ¶

type FindConfigTombstoneWarnThresholdDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigTombstoneWarnThresholdDefault handles this case with default header values.

unexpected error

func NewFindConfigTombstoneWarnThresholdDefault ¶

func NewFindConfigTombstoneWarnThresholdDefault(code int) *FindConfigTombstoneWarnThresholdDefault

NewFindConfigTombstoneWarnThresholdDefault creates a FindConfigTombstoneWarnThresholdDefault with default headers values

func (*FindConfigTombstoneWarnThresholdDefault) Code ¶

Code gets the status code for the find config tombstone warn threshold default response

func (*FindConfigTombstoneWarnThresholdDefault) Error ¶

func (*FindConfigTombstoneWarnThresholdDefault) GetPayload ¶

type FindConfigTombstoneWarnThresholdOK ¶

type FindConfigTombstoneWarnThresholdOK struct {
	Payload int64
}

FindConfigTombstoneWarnThresholdOK handles this case with default header values.

Config value

func NewFindConfigTombstoneWarnThresholdOK ¶

func NewFindConfigTombstoneWarnThresholdOK() *FindConfigTombstoneWarnThresholdOK

NewFindConfigTombstoneWarnThresholdOK creates a FindConfigTombstoneWarnThresholdOK with default headers values

func (*FindConfigTombstoneWarnThresholdOK) GetPayload ¶

func (o *FindConfigTombstoneWarnThresholdOK) GetPayload() int64

type FindConfigTombstoneWarnThresholdParams ¶

type FindConfigTombstoneWarnThresholdParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigTombstoneWarnThresholdParams contains all the parameters to send to the API endpoint for the find config tombstone warn threshold operation typically these are written to a http.Request

func NewFindConfigTombstoneWarnThresholdParams ¶

func NewFindConfigTombstoneWarnThresholdParams() *FindConfigTombstoneWarnThresholdParams

NewFindConfigTombstoneWarnThresholdParams creates a new FindConfigTombstoneWarnThresholdParams object with the default values initialized.

func NewFindConfigTombstoneWarnThresholdParamsWithContext ¶

func NewFindConfigTombstoneWarnThresholdParamsWithContext(ctx context.Context) *FindConfigTombstoneWarnThresholdParams

NewFindConfigTombstoneWarnThresholdParamsWithContext creates a new FindConfigTombstoneWarnThresholdParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigTombstoneWarnThresholdParamsWithHTTPClient ¶

func NewFindConfigTombstoneWarnThresholdParamsWithHTTPClient(client *http.Client) *FindConfigTombstoneWarnThresholdParams

NewFindConfigTombstoneWarnThresholdParamsWithHTTPClient creates a new FindConfigTombstoneWarnThresholdParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigTombstoneWarnThresholdParamsWithTimeout ¶

func NewFindConfigTombstoneWarnThresholdParamsWithTimeout(timeout time.Duration) *FindConfigTombstoneWarnThresholdParams

NewFindConfigTombstoneWarnThresholdParamsWithTimeout creates a new FindConfigTombstoneWarnThresholdParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigTombstoneWarnThresholdParams) SetContext ¶

SetContext adds the context to the find config tombstone warn threshold params

func (*FindConfigTombstoneWarnThresholdParams) SetHTTPClient ¶

func (o *FindConfigTombstoneWarnThresholdParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config tombstone warn threshold params

func (*FindConfigTombstoneWarnThresholdParams) SetTimeout ¶

func (o *FindConfigTombstoneWarnThresholdParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config tombstone warn threshold params

func (*FindConfigTombstoneWarnThresholdParams) WithContext ¶

WithContext adds the context to the find config tombstone warn threshold params

func (*FindConfigTombstoneWarnThresholdParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config tombstone warn threshold params

func (*FindConfigTombstoneWarnThresholdParams) WithTimeout ¶

WithTimeout adds the timeout to the find config tombstone warn threshold params

func (*FindConfigTombstoneWarnThresholdParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigTombstoneWarnThresholdReader ¶

type FindConfigTombstoneWarnThresholdReader struct {
	// contains filtered or unexported fields
}

FindConfigTombstoneWarnThresholdReader is a Reader for the FindConfigTombstoneWarnThreshold structure.

func (*FindConfigTombstoneWarnThresholdReader) ReadResponse ¶

func (o *FindConfigTombstoneWarnThresholdReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigTrickleFsyncDefault ¶

type FindConfigTrickleFsyncDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigTrickleFsyncDefault handles this case with default header values.

unexpected error

func NewFindConfigTrickleFsyncDefault ¶

func NewFindConfigTrickleFsyncDefault(code int) *FindConfigTrickleFsyncDefault

NewFindConfigTrickleFsyncDefault creates a FindConfigTrickleFsyncDefault with default headers values

func (*FindConfigTrickleFsyncDefault) Code ¶

Code gets the status code for the find config trickle fsync default response

func (*FindConfigTrickleFsyncDefault) Error ¶

func (*FindConfigTrickleFsyncDefault) GetPayload ¶

type FindConfigTrickleFsyncIntervalInKbDefault ¶

type FindConfigTrickleFsyncIntervalInKbDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigTrickleFsyncIntervalInKbDefault handles this case with default header values.

unexpected error

func NewFindConfigTrickleFsyncIntervalInKbDefault ¶

func NewFindConfigTrickleFsyncIntervalInKbDefault(code int) *FindConfigTrickleFsyncIntervalInKbDefault

NewFindConfigTrickleFsyncIntervalInKbDefault creates a FindConfigTrickleFsyncIntervalInKbDefault with default headers values

func (*FindConfigTrickleFsyncIntervalInKbDefault) Code ¶

Code gets the status code for the find config trickle fsync interval in kb default response

func (*FindConfigTrickleFsyncIntervalInKbDefault) Error ¶

func (*FindConfigTrickleFsyncIntervalInKbDefault) GetPayload ¶

type FindConfigTrickleFsyncIntervalInKbOK ¶

type FindConfigTrickleFsyncIntervalInKbOK struct {
	Payload int64
}

FindConfigTrickleFsyncIntervalInKbOK handles this case with default header values.

Config value

func NewFindConfigTrickleFsyncIntervalInKbOK ¶

func NewFindConfigTrickleFsyncIntervalInKbOK() *FindConfigTrickleFsyncIntervalInKbOK

NewFindConfigTrickleFsyncIntervalInKbOK creates a FindConfigTrickleFsyncIntervalInKbOK with default headers values

func (*FindConfigTrickleFsyncIntervalInKbOK) GetPayload ¶

type FindConfigTrickleFsyncIntervalInKbParams ¶

type FindConfigTrickleFsyncIntervalInKbParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigTrickleFsyncIntervalInKbParams contains all the parameters to send to the API endpoint for the find config trickle fsync interval in kb operation typically these are written to a http.Request

func NewFindConfigTrickleFsyncIntervalInKbParams ¶

func NewFindConfigTrickleFsyncIntervalInKbParams() *FindConfigTrickleFsyncIntervalInKbParams

NewFindConfigTrickleFsyncIntervalInKbParams creates a new FindConfigTrickleFsyncIntervalInKbParams object with the default values initialized.

func NewFindConfigTrickleFsyncIntervalInKbParamsWithContext ¶

func NewFindConfigTrickleFsyncIntervalInKbParamsWithContext(ctx context.Context) *FindConfigTrickleFsyncIntervalInKbParams

NewFindConfigTrickleFsyncIntervalInKbParamsWithContext creates a new FindConfigTrickleFsyncIntervalInKbParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigTrickleFsyncIntervalInKbParamsWithHTTPClient ¶

func NewFindConfigTrickleFsyncIntervalInKbParamsWithHTTPClient(client *http.Client) *FindConfigTrickleFsyncIntervalInKbParams

NewFindConfigTrickleFsyncIntervalInKbParamsWithHTTPClient creates a new FindConfigTrickleFsyncIntervalInKbParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigTrickleFsyncIntervalInKbParamsWithTimeout ¶

func NewFindConfigTrickleFsyncIntervalInKbParamsWithTimeout(timeout time.Duration) *FindConfigTrickleFsyncIntervalInKbParams

NewFindConfigTrickleFsyncIntervalInKbParamsWithTimeout creates a new FindConfigTrickleFsyncIntervalInKbParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigTrickleFsyncIntervalInKbParams) SetContext ¶

SetContext adds the context to the find config trickle fsync interval in kb params

func (*FindConfigTrickleFsyncIntervalInKbParams) SetHTTPClient ¶

func (o *FindConfigTrickleFsyncIntervalInKbParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config trickle fsync interval in kb params

func (*FindConfigTrickleFsyncIntervalInKbParams) SetTimeout ¶

SetTimeout adds the timeout to the find config trickle fsync interval in kb params

func (*FindConfigTrickleFsyncIntervalInKbParams) WithContext ¶

WithContext adds the context to the find config trickle fsync interval in kb params

func (*FindConfigTrickleFsyncIntervalInKbParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config trickle fsync interval in kb params

func (*FindConfigTrickleFsyncIntervalInKbParams) WithTimeout ¶

WithTimeout adds the timeout to the find config trickle fsync interval in kb params

func (*FindConfigTrickleFsyncIntervalInKbParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigTrickleFsyncIntervalInKbReader ¶

type FindConfigTrickleFsyncIntervalInKbReader struct {
	// contains filtered or unexported fields
}

FindConfigTrickleFsyncIntervalInKbReader is a Reader for the FindConfigTrickleFsyncIntervalInKb structure.

func (*FindConfigTrickleFsyncIntervalInKbReader) ReadResponse ¶

func (o *FindConfigTrickleFsyncIntervalInKbReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigTrickleFsyncOK ¶

type FindConfigTrickleFsyncOK struct {
	Payload bool
}

FindConfigTrickleFsyncOK handles this case with default header values.

Config value

func NewFindConfigTrickleFsyncOK ¶

func NewFindConfigTrickleFsyncOK() *FindConfigTrickleFsyncOK

NewFindConfigTrickleFsyncOK creates a FindConfigTrickleFsyncOK with default headers values

func (*FindConfigTrickleFsyncOK) GetPayload ¶

func (o *FindConfigTrickleFsyncOK) GetPayload() bool

type FindConfigTrickleFsyncParams ¶

type FindConfigTrickleFsyncParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigTrickleFsyncParams contains all the parameters to send to the API endpoint for the find config trickle fsync operation typically these are written to a http.Request

func NewFindConfigTrickleFsyncParams ¶

func NewFindConfigTrickleFsyncParams() *FindConfigTrickleFsyncParams

NewFindConfigTrickleFsyncParams creates a new FindConfigTrickleFsyncParams object with the default values initialized.

func NewFindConfigTrickleFsyncParamsWithContext ¶

func NewFindConfigTrickleFsyncParamsWithContext(ctx context.Context) *FindConfigTrickleFsyncParams

NewFindConfigTrickleFsyncParamsWithContext creates a new FindConfigTrickleFsyncParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigTrickleFsyncParamsWithHTTPClient ¶

func NewFindConfigTrickleFsyncParamsWithHTTPClient(client *http.Client) *FindConfigTrickleFsyncParams

NewFindConfigTrickleFsyncParamsWithHTTPClient creates a new FindConfigTrickleFsyncParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigTrickleFsyncParamsWithTimeout ¶

func NewFindConfigTrickleFsyncParamsWithTimeout(timeout time.Duration) *FindConfigTrickleFsyncParams

NewFindConfigTrickleFsyncParamsWithTimeout creates a new FindConfigTrickleFsyncParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigTrickleFsyncParams) SetContext ¶

func (o *FindConfigTrickleFsyncParams) SetContext(ctx context.Context)

SetContext adds the context to the find config trickle fsync params

func (*FindConfigTrickleFsyncParams) SetHTTPClient ¶

func (o *FindConfigTrickleFsyncParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config trickle fsync params

func (*FindConfigTrickleFsyncParams) SetTimeout ¶

func (o *FindConfigTrickleFsyncParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config trickle fsync params

func (*FindConfigTrickleFsyncParams) WithContext ¶

WithContext adds the context to the find config trickle fsync params

func (*FindConfigTrickleFsyncParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config trickle fsync params

func (*FindConfigTrickleFsyncParams) WithTimeout ¶

WithTimeout adds the timeout to the find config trickle fsync params

func (*FindConfigTrickleFsyncParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigTrickleFsyncReader ¶

type FindConfigTrickleFsyncReader struct {
	// contains filtered or unexported fields
}

FindConfigTrickleFsyncReader is a Reader for the FindConfigTrickleFsync structure.

func (*FindConfigTrickleFsyncReader) ReadResponse ¶

func (o *FindConfigTrickleFsyncReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigTruncateRequestTimeoutInMsDefault ¶

type FindConfigTruncateRequestTimeoutInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigTruncateRequestTimeoutInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigTruncateRequestTimeoutInMsDefault ¶

func NewFindConfigTruncateRequestTimeoutInMsDefault(code int) *FindConfigTruncateRequestTimeoutInMsDefault

NewFindConfigTruncateRequestTimeoutInMsDefault creates a FindConfigTruncateRequestTimeoutInMsDefault with default headers values

func (*FindConfigTruncateRequestTimeoutInMsDefault) Code ¶

Code gets the status code for the find config truncate request timeout in ms default response

func (*FindConfigTruncateRequestTimeoutInMsDefault) Error ¶

func (*FindConfigTruncateRequestTimeoutInMsDefault) GetPayload ¶

type FindConfigTruncateRequestTimeoutInMsOK ¶

type FindConfigTruncateRequestTimeoutInMsOK struct {
	Payload int64
}

FindConfigTruncateRequestTimeoutInMsOK handles this case with default header values.

Config value

func NewFindConfigTruncateRequestTimeoutInMsOK ¶

func NewFindConfigTruncateRequestTimeoutInMsOK() *FindConfigTruncateRequestTimeoutInMsOK

NewFindConfigTruncateRequestTimeoutInMsOK creates a FindConfigTruncateRequestTimeoutInMsOK with default headers values

func (*FindConfigTruncateRequestTimeoutInMsOK) GetPayload ¶

type FindConfigTruncateRequestTimeoutInMsParams ¶

type FindConfigTruncateRequestTimeoutInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigTruncateRequestTimeoutInMsParams contains all the parameters to send to the API endpoint for the find config truncate request timeout in ms operation typically these are written to a http.Request

func NewFindConfigTruncateRequestTimeoutInMsParams ¶

func NewFindConfigTruncateRequestTimeoutInMsParams() *FindConfigTruncateRequestTimeoutInMsParams

NewFindConfigTruncateRequestTimeoutInMsParams creates a new FindConfigTruncateRequestTimeoutInMsParams object with the default values initialized.

func NewFindConfigTruncateRequestTimeoutInMsParamsWithContext ¶

func NewFindConfigTruncateRequestTimeoutInMsParamsWithContext(ctx context.Context) *FindConfigTruncateRequestTimeoutInMsParams

NewFindConfigTruncateRequestTimeoutInMsParamsWithContext creates a new FindConfigTruncateRequestTimeoutInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigTruncateRequestTimeoutInMsParamsWithHTTPClient ¶

func NewFindConfigTruncateRequestTimeoutInMsParamsWithHTTPClient(client *http.Client) *FindConfigTruncateRequestTimeoutInMsParams

NewFindConfigTruncateRequestTimeoutInMsParamsWithHTTPClient creates a new FindConfigTruncateRequestTimeoutInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigTruncateRequestTimeoutInMsParamsWithTimeout ¶

func NewFindConfigTruncateRequestTimeoutInMsParamsWithTimeout(timeout time.Duration) *FindConfigTruncateRequestTimeoutInMsParams

NewFindConfigTruncateRequestTimeoutInMsParamsWithTimeout creates a new FindConfigTruncateRequestTimeoutInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigTruncateRequestTimeoutInMsParams) SetContext ¶

SetContext adds the context to the find config truncate request timeout in ms params

func (*FindConfigTruncateRequestTimeoutInMsParams) SetHTTPClient ¶

func (o *FindConfigTruncateRequestTimeoutInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config truncate request timeout in ms params

func (*FindConfigTruncateRequestTimeoutInMsParams) SetTimeout ¶

SetTimeout adds the timeout to the find config truncate request timeout in ms params

func (*FindConfigTruncateRequestTimeoutInMsParams) WithContext ¶

WithContext adds the context to the find config truncate request timeout in ms params

func (*FindConfigTruncateRequestTimeoutInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config truncate request timeout in ms params

func (*FindConfigTruncateRequestTimeoutInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config truncate request timeout in ms params

func (*FindConfigTruncateRequestTimeoutInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigTruncateRequestTimeoutInMsReader ¶

type FindConfigTruncateRequestTimeoutInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigTruncateRequestTimeoutInMsReader is a Reader for the FindConfigTruncateRequestTimeoutInMs structure.

func (*FindConfigTruncateRequestTimeoutInMsReader) ReadResponse ¶

func (o *FindConfigTruncateRequestTimeoutInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigViewBuildingDefault ¶

type FindConfigViewBuildingDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigViewBuildingDefault handles this case with default header values.

unexpected error

func NewFindConfigViewBuildingDefault ¶

func NewFindConfigViewBuildingDefault(code int) *FindConfigViewBuildingDefault

NewFindConfigViewBuildingDefault creates a FindConfigViewBuildingDefault with default headers values

func (*FindConfigViewBuildingDefault) Code ¶

Code gets the status code for the find config view building default response

func (*FindConfigViewBuildingDefault) Error ¶

func (*FindConfigViewBuildingDefault) GetPayload ¶

type FindConfigViewBuildingOK ¶

type FindConfigViewBuildingOK struct {
	Payload bool
}

FindConfigViewBuildingOK handles this case with default header values.

Config value

func NewFindConfigViewBuildingOK ¶

func NewFindConfigViewBuildingOK() *FindConfigViewBuildingOK

NewFindConfigViewBuildingOK creates a FindConfigViewBuildingOK with default headers values

func (*FindConfigViewBuildingOK) GetPayload ¶

func (o *FindConfigViewBuildingOK) GetPayload() bool

type FindConfigViewBuildingParams ¶

type FindConfigViewBuildingParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigViewBuildingParams contains all the parameters to send to the API endpoint for the find config view building operation typically these are written to a http.Request

func NewFindConfigViewBuildingParams ¶

func NewFindConfigViewBuildingParams() *FindConfigViewBuildingParams

NewFindConfigViewBuildingParams creates a new FindConfigViewBuildingParams object with the default values initialized.

func NewFindConfigViewBuildingParamsWithContext ¶

func NewFindConfigViewBuildingParamsWithContext(ctx context.Context) *FindConfigViewBuildingParams

NewFindConfigViewBuildingParamsWithContext creates a new FindConfigViewBuildingParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigViewBuildingParamsWithHTTPClient ¶

func NewFindConfigViewBuildingParamsWithHTTPClient(client *http.Client) *FindConfigViewBuildingParams

NewFindConfigViewBuildingParamsWithHTTPClient creates a new FindConfigViewBuildingParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigViewBuildingParamsWithTimeout ¶

func NewFindConfigViewBuildingParamsWithTimeout(timeout time.Duration) *FindConfigViewBuildingParams

NewFindConfigViewBuildingParamsWithTimeout creates a new FindConfigViewBuildingParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigViewBuildingParams) SetContext ¶

func (o *FindConfigViewBuildingParams) SetContext(ctx context.Context)

SetContext adds the context to the find config view building params

func (*FindConfigViewBuildingParams) SetHTTPClient ¶

func (o *FindConfigViewBuildingParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config view building params

func (*FindConfigViewBuildingParams) SetTimeout ¶

func (o *FindConfigViewBuildingParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config view building params

func (*FindConfigViewBuildingParams) WithContext ¶

WithContext adds the context to the find config view building params

func (*FindConfigViewBuildingParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config view building params

func (*FindConfigViewBuildingParams) WithTimeout ¶

WithTimeout adds the timeout to the find config view building params

func (*FindConfigViewBuildingParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigViewBuildingReader ¶

type FindConfigViewBuildingReader struct {
	// contains filtered or unexported fields
}

FindConfigViewBuildingReader is a Reader for the FindConfigViewBuilding structure.

func (*FindConfigViewBuildingReader) ReadResponse ¶

func (o *FindConfigViewBuildingReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigViewHintsDirectoryDefault ¶

type FindConfigViewHintsDirectoryDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigViewHintsDirectoryDefault handles this case with default header values.

unexpected error

func NewFindConfigViewHintsDirectoryDefault ¶

func NewFindConfigViewHintsDirectoryDefault(code int) *FindConfigViewHintsDirectoryDefault

NewFindConfigViewHintsDirectoryDefault creates a FindConfigViewHintsDirectoryDefault with default headers values

func (*FindConfigViewHintsDirectoryDefault) Code ¶

Code gets the status code for the find config view hints directory default response

func (*FindConfigViewHintsDirectoryDefault) Error ¶

func (*FindConfigViewHintsDirectoryDefault) GetPayload ¶

type FindConfigViewHintsDirectoryOK ¶

type FindConfigViewHintsDirectoryOK struct {
	Payload string
}

FindConfigViewHintsDirectoryOK handles this case with default header values.

Config value

func NewFindConfigViewHintsDirectoryOK ¶

func NewFindConfigViewHintsDirectoryOK() *FindConfigViewHintsDirectoryOK

NewFindConfigViewHintsDirectoryOK creates a FindConfigViewHintsDirectoryOK with default headers values

func (*FindConfigViewHintsDirectoryOK) GetPayload ¶

func (o *FindConfigViewHintsDirectoryOK) GetPayload() string

type FindConfigViewHintsDirectoryParams ¶

type FindConfigViewHintsDirectoryParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigViewHintsDirectoryParams contains all the parameters to send to the API endpoint for the find config view hints directory operation typically these are written to a http.Request

func NewFindConfigViewHintsDirectoryParams ¶

func NewFindConfigViewHintsDirectoryParams() *FindConfigViewHintsDirectoryParams

NewFindConfigViewHintsDirectoryParams creates a new FindConfigViewHintsDirectoryParams object with the default values initialized.

func NewFindConfigViewHintsDirectoryParamsWithContext ¶

func NewFindConfigViewHintsDirectoryParamsWithContext(ctx context.Context) *FindConfigViewHintsDirectoryParams

NewFindConfigViewHintsDirectoryParamsWithContext creates a new FindConfigViewHintsDirectoryParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigViewHintsDirectoryParamsWithHTTPClient ¶

func NewFindConfigViewHintsDirectoryParamsWithHTTPClient(client *http.Client) *FindConfigViewHintsDirectoryParams

NewFindConfigViewHintsDirectoryParamsWithHTTPClient creates a new FindConfigViewHintsDirectoryParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigViewHintsDirectoryParamsWithTimeout ¶

func NewFindConfigViewHintsDirectoryParamsWithTimeout(timeout time.Duration) *FindConfigViewHintsDirectoryParams

NewFindConfigViewHintsDirectoryParamsWithTimeout creates a new FindConfigViewHintsDirectoryParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigViewHintsDirectoryParams) SetContext ¶

SetContext adds the context to the find config view hints directory params

func (*FindConfigViewHintsDirectoryParams) SetHTTPClient ¶

func (o *FindConfigViewHintsDirectoryParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config view hints directory params

func (*FindConfigViewHintsDirectoryParams) SetTimeout ¶

func (o *FindConfigViewHintsDirectoryParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config view hints directory params

func (*FindConfigViewHintsDirectoryParams) WithContext ¶

WithContext adds the context to the find config view hints directory params

func (*FindConfigViewHintsDirectoryParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config view hints directory params

func (*FindConfigViewHintsDirectoryParams) WithTimeout ¶

WithTimeout adds the timeout to the find config view hints directory params

func (*FindConfigViewHintsDirectoryParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigViewHintsDirectoryReader ¶

type FindConfigViewHintsDirectoryReader struct {
	// contains filtered or unexported fields
}

FindConfigViewHintsDirectoryReader is a Reader for the FindConfigViewHintsDirectory structure.

func (*FindConfigViewHintsDirectoryReader) ReadResponse ¶

func (o *FindConfigViewHintsDirectoryReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigVirtualDirtySoftLimitDefault ¶

type FindConfigVirtualDirtySoftLimitDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigVirtualDirtySoftLimitDefault handles this case with default header values.

unexpected error

func NewFindConfigVirtualDirtySoftLimitDefault ¶

func NewFindConfigVirtualDirtySoftLimitDefault(code int) *FindConfigVirtualDirtySoftLimitDefault

NewFindConfigVirtualDirtySoftLimitDefault creates a FindConfigVirtualDirtySoftLimitDefault with default headers values

func (*FindConfigVirtualDirtySoftLimitDefault) Code ¶

Code gets the status code for the find config virtual dirty soft limit default response

func (*FindConfigVirtualDirtySoftLimitDefault) Error ¶

func (*FindConfigVirtualDirtySoftLimitDefault) GetPayload ¶

type FindConfigVirtualDirtySoftLimitOK ¶

type FindConfigVirtualDirtySoftLimitOK struct {
	Payload float64
}

FindConfigVirtualDirtySoftLimitOK handles this case with default header values.

Config value

func NewFindConfigVirtualDirtySoftLimitOK ¶

func NewFindConfigVirtualDirtySoftLimitOK() *FindConfigVirtualDirtySoftLimitOK

NewFindConfigVirtualDirtySoftLimitOK creates a FindConfigVirtualDirtySoftLimitOK with default headers values

func (*FindConfigVirtualDirtySoftLimitOK) GetPayload ¶

type FindConfigVirtualDirtySoftLimitParams ¶

type FindConfigVirtualDirtySoftLimitParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigVirtualDirtySoftLimitParams contains all the parameters to send to the API endpoint for the find config virtual dirty soft limit operation typically these are written to a http.Request

func NewFindConfigVirtualDirtySoftLimitParams ¶

func NewFindConfigVirtualDirtySoftLimitParams() *FindConfigVirtualDirtySoftLimitParams

NewFindConfigVirtualDirtySoftLimitParams creates a new FindConfigVirtualDirtySoftLimitParams object with the default values initialized.

func NewFindConfigVirtualDirtySoftLimitParamsWithContext ¶

func NewFindConfigVirtualDirtySoftLimitParamsWithContext(ctx context.Context) *FindConfigVirtualDirtySoftLimitParams

NewFindConfigVirtualDirtySoftLimitParamsWithContext creates a new FindConfigVirtualDirtySoftLimitParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigVirtualDirtySoftLimitParamsWithHTTPClient ¶

func NewFindConfigVirtualDirtySoftLimitParamsWithHTTPClient(client *http.Client) *FindConfigVirtualDirtySoftLimitParams

NewFindConfigVirtualDirtySoftLimitParamsWithHTTPClient creates a new FindConfigVirtualDirtySoftLimitParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigVirtualDirtySoftLimitParamsWithTimeout ¶

func NewFindConfigVirtualDirtySoftLimitParamsWithTimeout(timeout time.Duration) *FindConfigVirtualDirtySoftLimitParams

NewFindConfigVirtualDirtySoftLimitParamsWithTimeout creates a new FindConfigVirtualDirtySoftLimitParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigVirtualDirtySoftLimitParams) SetContext ¶

SetContext adds the context to the find config virtual dirty soft limit params

func (*FindConfigVirtualDirtySoftLimitParams) SetHTTPClient ¶

func (o *FindConfigVirtualDirtySoftLimitParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config virtual dirty soft limit params

func (*FindConfigVirtualDirtySoftLimitParams) SetTimeout ¶

func (o *FindConfigVirtualDirtySoftLimitParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config virtual dirty soft limit params

func (*FindConfigVirtualDirtySoftLimitParams) WithContext ¶

WithContext adds the context to the find config virtual dirty soft limit params

func (*FindConfigVirtualDirtySoftLimitParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config virtual dirty soft limit params

func (*FindConfigVirtualDirtySoftLimitParams) WithTimeout ¶

WithTimeout adds the timeout to the find config virtual dirty soft limit params

func (*FindConfigVirtualDirtySoftLimitParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigVirtualDirtySoftLimitReader ¶

type FindConfigVirtualDirtySoftLimitReader struct {
	// contains filtered or unexported fields
}

FindConfigVirtualDirtySoftLimitReader is a Reader for the FindConfigVirtualDirtySoftLimit structure.

func (*FindConfigVirtualDirtySoftLimitReader) ReadResponse ¶

func (o *FindConfigVirtualDirtySoftLimitReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigVolatileSystemKeyspaceForTestingDefault ¶

type FindConfigVolatileSystemKeyspaceForTestingDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigVolatileSystemKeyspaceForTestingDefault handles this case with default header values.

unexpected error

func NewFindConfigVolatileSystemKeyspaceForTestingDefault ¶

func NewFindConfigVolatileSystemKeyspaceForTestingDefault(code int) *FindConfigVolatileSystemKeyspaceForTestingDefault

NewFindConfigVolatileSystemKeyspaceForTestingDefault creates a FindConfigVolatileSystemKeyspaceForTestingDefault with default headers values

func (*FindConfigVolatileSystemKeyspaceForTestingDefault) Code ¶

Code gets the status code for the find config volatile system keyspace for testing default response

func (*FindConfigVolatileSystemKeyspaceForTestingDefault) Error ¶

func (*FindConfigVolatileSystemKeyspaceForTestingDefault) GetPayload ¶

type FindConfigVolatileSystemKeyspaceForTestingOK ¶

type FindConfigVolatileSystemKeyspaceForTestingOK struct {
	Payload bool
}

FindConfigVolatileSystemKeyspaceForTestingOK handles this case with default header values.

Config value

func NewFindConfigVolatileSystemKeyspaceForTestingOK ¶

func NewFindConfigVolatileSystemKeyspaceForTestingOK() *FindConfigVolatileSystemKeyspaceForTestingOK

NewFindConfigVolatileSystemKeyspaceForTestingOK creates a FindConfigVolatileSystemKeyspaceForTestingOK with default headers values

func (*FindConfigVolatileSystemKeyspaceForTestingOK) GetPayload ¶

type FindConfigVolatileSystemKeyspaceForTestingParams ¶

type FindConfigVolatileSystemKeyspaceForTestingParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigVolatileSystemKeyspaceForTestingParams contains all the parameters to send to the API endpoint for the find config volatile system keyspace for testing operation typically these are written to a http.Request

func NewFindConfigVolatileSystemKeyspaceForTestingParams ¶

func NewFindConfigVolatileSystemKeyspaceForTestingParams() *FindConfigVolatileSystemKeyspaceForTestingParams

NewFindConfigVolatileSystemKeyspaceForTestingParams creates a new FindConfigVolatileSystemKeyspaceForTestingParams object with the default values initialized.

func NewFindConfigVolatileSystemKeyspaceForTestingParamsWithContext ¶

func NewFindConfigVolatileSystemKeyspaceForTestingParamsWithContext(ctx context.Context) *FindConfigVolatileSystemKeyspaceForTestingParams

NewFindConfigVolatileSystemKeyspaceForTestingParamsWithContext creates a new FindConfigVolatileSystemKeyspaceForTestingParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigVolatileSystemKeyspaceForTestingParamsWithHTTPClient ¶

func NewFindConfigVolatileSystemKeyspaceForTestingParamsWithHTTPClient(client *http.Client) *FindConfigVolatileSystemKeyspaceForTestingParams

NewFindConfigVolatileSystemKeyspaceForTestingParamsWithHTTPClient creates a new FindConfigVolatileSystemKeyspaceForTestingParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigVolatileSystemKeyspaceForTestingParamsWithTimeout ¶

func NewFindConfigVolatileSystemKeyspaceForTestingParamsWithTimeout(timeout time.Duration) *FindConfigVolatileSystemKeyspaceForTestingParams

NewFindConfigVolatileSystemKeyspaceForTestingParamsWithTimeout creates a new FindConfigVolatileSystemKeyspaceForTestingParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigVolatileSystemKeyspaceForTestingParams) SetContext ¶

SetContext adds the context to the find config volatile system keyspace for testing params

func (*FindConfigVolatileSystemKeyspaceForTestingParams) SetHTTPClient ¶

SetHTTPClient adds the HTTPClient to the find config volatile system keyspace for testing params

func (*FindConfigVolatileSystemKeyspaceForTestingParams) SetTimeout ¶

SetTimeout adds the timeout to the find config volatile system keyspace for testing params

func (*FindConfigVolatileSystemKeyspaceForTestingParams) WithContext ¶

WithContext adds the context to the find config volatile system keyspace for testing params

func (*FindConfigVolatileSystemKeyspaceForTestingParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config volatile system keyspace for testing params

func (*FindConfigVolatileSystemKeyspaceForTestingParams) WithTimeout ¶

WithTimeout adds the timeout to the find config volatile system keyspace for testing params

func (*FindConfigVolatileSystemKeyspaceForTestingParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigVolatileSystemKeyspaceForTestingReader ¶

type FindConfigVolatileSystemKeyspaceForTestingReader struct {
	// contains filtered or unexported fields
}

FindConfigVolatileSystemKeyspaceForTestingReader is a Reader for the FindConfigVolatileSystemKeyspaceForTesting structure.

func (*FindConfigVolatileSystemKeyspaceForTestingReader) ReadResponse ¶

func (o *FindConfigVolatileSystemKeyspaceForTestingReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

type FindConfigWriteRequestTimeoutInMsDefault ¶

type FindConfigWriteRequestTimeoutInMsDefault struct {
	Payload *models.ErrorModel
	// contains filtered or unexported fields
}

FindConfigWriteRequestTimeoutInMsDefault handles this case with default header values.

unexpected error

func NewFindConfigWriteRequestTimeoutInMsDefault ¶

func NewFindConfigWriteRequestTimeoutInMsDefault(code int) *FindConfigWriteRequestTimeoutInMsDefault

NewFindConfigWriteRequestTimeoutInMsDefault creates a FindConfigWriteRequestTimeoutInMsDefault with default headers values

func (*FindConfigWriteRequestTimeoutInMsDefault) Code ¶

Code gets the status code for the find config write request timeout in ms default response

func (*FindConfigWriteRequestTimeoutInMsDefault) Error ¶

func (*FindConfigWriteRequestTimeoutInMsDefault) GetPayload ¶

type FindConfigWriteRequestTimeoutInMsOK ¶

type FindConfigWriteRequestTimeoutInMsOK struct {
	Payload int64
}

FindConfigWriteRequestTimeoutInMsOK handles this case with default header values.

Config value

func NewFindConfigWriteRequestTimeoutInMsOK ¶

func NewFindConfigWriteRequestTimeoutInMsOK() *FindConfigWriteRequestTimeoutInMsOK

NewFindConfigWriteRequestTimeoutInMsOK creates a FindConfigWriteRequestTimeoutInMsOK with default headers values

func (*FindConfigWriteRequestTimeoutInMsOK) GetPayload ¶

type FindConfigWriteRequestTimeoutInMsParams ¶

type FindConfigWriteRequestTimeoutInMsParams struct {
	Context    context.Context
	HTTPClient *http.Client
	// contains filtered or unexported fields
}

FindConfigWriteRequestTimeoutInMsParams contains all the parameters to send to the API endpoint for the find config write request timeout in ms operation typically these are written to a http.Request

func NewFindConfigWriteRequestTimeoutInMsParams ¶

func NewFindConfigWriteRequestTimeoutInMsParams() *FindConfigWriteRequestTimeoutInMsParams

NewFindConfigWriteRequestTimeoutInMsParams creates a new FindConfigWriteRequestTimeoutInMsParams object with the default values initialized.

func NewFindConfigWriteRequestTimeoutInMsParamsWithContext ¶

func NewFindConfigWriteRequestTimeoutInMsParamsWithContext(ctx context.Context) *FindConfigWriteRequestTimeoutInMsParams

NewFindConfigWriteRequestTimeoutInMsParamsWithContext creates a new FindConfigWriteRequestTimeoutInMsParams object with the default values initialized, and the ability to set a context for a request

func NewFindConfigWriteRequestTimeoutInMsParamsWithHTTPClient ¶

func NewFindConfigWriteRequestTimeoutInMsParamsWithHTTPClient(client *http.Client) *FindConfigWriteRequestTimeoutInMsParams

NewFindConfigWriteRequestTimeoutInMsParamsWithHTTPClient creates a new FindConfigWriteRequestTimeoutInMsParams object with the default values initialized, and the ability to set a custom HTTPClient for a request

func NewFindConfigWriteRequestTimeoutInMsParamsWithTimeout ¶

func NewFindConfigWriteRequestTimeoutInMsParamsWithTimeout(timeout time.Duration) *FindConfigWriteRequestTimeoutInMsParams

NewFindConfigWriteRequestTimeoutInMsParamsWithTimeout creates a new FindConfigWriteRequestTimeoutInMsParams object with the default values initialized, and the ability to set a timeout on a request

func (*FindConfigWriteRequestTimeoutInMsParams) SetContext ¶

SetContext adds the context to the find config write request timeout in ms params

func (*FindConfigWriteRequestTimeoutInMsParams) SetHTTPClient ¶

func (o *FindConfigWriteRequestTimeoutInMsParams) SetHTTPClient(client *http.Client)

SetHTTPClient adds the HTTPClient to the find config write request timeout in ms params

func (*FindConfigWriteRequestTimeoutInMsParams) SetTimeout ¶

func (o *FindConfigWriteRequestTimeoutInMsParams) SetTimeout(timeout time.Duration)

SetTimeout adds the timeout to the find config write request timeout in ms params

func (*FindConfigWriteRequestTimeoutInMsParams) WithContext ¶

WithContext adds the context to the find config write request timeout in ms params

func (*FindConfigWriteRequestTimeoutInMsParams) WithHTTPClient ¶

WithHTTPClient adds the HTTPClient to the find config write request timeout in ms params

func (*FindConfigWriteRequestTimeoutInMsParams) WithTimeout ¶

WithTimeout adds the timeout to the find config write request timeout in ms params

func (*FindConfigWriteRequestTimeoutInMsParams) WriteToRequest ¶

WriteToRequest writes these params to a swagger request

type FindConfigWriteRequestTimeoutInMsReader ¶

type FindConfigWriteRequestTimeoutInMsReader struct {
	// contains filtered or unexported fields
}

FindConfigWriteRequestTimeoutInMsReader is a Reader for the FindConfigWriteRequestTimeoutInMs structure.

func (*FindConfigWriteRequestTimeoutInMsReader) ReadResponse ¶

func (o *FindConfigWriteRequestTimeoutInMsReader) ReadResponse(response runtime.ClientResponse, consumer runtime.Consumer) (interface{}, error)

ReadResponse reads a server response into the received o.

Source Files ¶

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL