ytconfig

package
v0.0.0-...-cfe22c1 Latest Latest
Warning

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

Go to latest
Published: Apr 26, 2024 License: Apache-2.0 Imports: 16 Imported by: 0

Documentation

Index

Constants

View Source
const (
	ConfigFormatYson               = "yson"
	ConfigFormatJson               = "json"
	ConfigFormatJsonWithJsPrologue = "json_with_js_prologue"
	ConfigFormatToml               = "toml"
)

Variables

This section is empty.

Functions

func RandString

func RandString(n int) string

Types

type AddressList

type AddressList struct {
	Addresses []string `yson:"addresses"`
}

type AddressResolver

type AddressResolver struct {
	EnableIPv4 bool `yson:"enable_ipv4"`
	EnableIPv6 bool `yson:"enable_ipv6"`
	Retries    *int `yson:"retries,omitempty"`

	LocalhostNameOverride *string `yson:"localhost_name_override,omitempty"`
}

type Auth

type Auth struct {
	CypressCookieManager      CypressCookieManager      `yson:"cypress_cookie_manager"`
	CypressUserManager        CypressUserManager        `yson:"cypress_user_manager"`
	CypressTokenAuthenticator CypressTokenAuthenticator `yson:"cypress_token_authenticator"`
	OauthService              *OauthService             `yson:"oauth_service,omitempty"`
	OauthCookieAuthenticator  *OauthCookieAuthenticator `yson:"oauth_cookie_authenticator,omitempty"`
	OauthTokenAuthenticator   *OauthTokenAuthenticator  `yson:"oauth_token_authenticator,omitempty"`
	RequireAuthentication     bool                      `yson:"require_authentication"`
}

type BaseGenerator

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

func NewLocalBaseGenerator

func NewLocalBaseGenerator(
	ytsaurus *ytv1.Ytsaurus,
	clusterDomain string,
) *BaseGenerator

func NewRemoteBaseGenerator

func NewRemoteBaseGenerator(
	key types.NamespacedName,
	clusterDomain string,
	commonSpec ytv1.CommonSpec,
	masterConnectionSpec ytv1.MasterConnectionSpec,
	masterCachesSpec *ytv1.MasterCachesSpec,
) *BaseGenerator

func (*BaseGenerator) FormatComponentStringWithDefault

func (g *BaseGenerator) FormatComponentStringWithDefault(base string, name string) string

func (*BaseGenerator) GetDiscoveryPodNames

func (g *BaseGenerator) GetDiscoveryPodNames() []string

func (*BaseGenerator) GetDiscoveryServiceName

func (g *BaseGenerator) GetDiscoveryServiceName() string

func (*BaseGenerator) GetDiscoveryStatefulSetName

func (g *BaseGenerator) GetDiscoveryStatefulSetName() string

func (*BaseGenerator) GetMasterCachesPodNames

func (g *BaseGenerator) GetMasterCachesPodNames() []string

func (*BaseGenerator) GetMasterCachesServiceName

func (g *BaseGenerator) GetMasterCachesServiceName() string

func (*BaseGenerator) GetMasterCachesStatefulSetName

func (g *BaseGenerator) GetMasterCachesStatefulSetName() string

func (*BaseGenerator) GetMasterPodNames

func (g *BaseGenerator) GetMasterPodNames() []string

func (*BaseGenerator) GetMastersServiceName

func (g *BaseGenerator) GetMastersServiceName() string

func (*BaseGenerator) GetMastersStatefulSetName

func (g *BaseGenerator) GetMastersStatefulSetName() string

func (*BaseGenerator) GetMaxReplicationFactor

func (g *BaseGenerator) GetMaxReplicationFactor() int32

type BasicServer

type BasicServer struct {
	AddressResolver AddressResolver `yson:"address_resolver"`
	Logging         Logging         `yson:"logging"`
	MonitoringPort  int32           `yson:"monitoring_port"`
	RPCPort         int32           `yson:"rpc_port"`
	BusServer       *BusServer      `yson:"bus_server,omitempty"`
}

BasicServer is used as a basic config for basic components, such as clocks or discovery.

type BindMount

type BindMount struct {
	ExternalPath string `yson:"external_path"`
	InternalPath string `yson:"internal_path"`
	ReadOnly     bool   `yson:"read_only"`
}

type BlockCache

type BlockCache struct {
	Compressed   Cache `yson:"compressed_data"`
	Uncompressed Cache `yson:"uncompressed_data"`
}

type Bus

type Bus struct {
	EncryptionMode EncryptionMode `yson:"encryption_mode,omitempty"`
	CertChain      *PemBlob       `yson:"cert_chain,omitempty"`
	PrivateKey     *PemBlob       `yson:"private_key,omitempty"`
	CipherList     []string       `yson:"cipher_list,omitempty"`

	CA                      *PemBlob         `yson:"ca,omitempty"`
	VerificationMode        VerificationMode `yson:"verification_mode,omitempty"`
	PeerAlternativeHostName string           `yson:"peer_alternative_host_name,omitempty"`
}

type BusServer

type BusServer struct {
	Bus
}

type Cache

type Cache struct {
	Capacity int64 `yson:"capacity"`
}

type CacheLocation

type CacheLocation struct {
	Path     string    `yson:"path"`
	IOEngine *IOEngine `yson:"io_config,omitempty"`
}

type ChytInitCluster

type ChytInitCluster struct {
	Proxy          string   `yson:"proxy"`
	StrawberryRoot string   `yson:"strawberry_root"`
	Families       []string `yson:"families"`
}

type ClusterConnection

type ClusterConnection struct {
	ClusterName         string              `yson:"cluster_name"`
	PrimaryMaster       MasterCell          `yson:"primary_master"`
	DiscoveryConnection DiscoveryConnection `yson:"discovery_connection,omitempty"`
	BusClient           *Bus                `yson:"bus_client,omitempty"`
	MasterCache         MasterCache         `yson:"master_cache"`
}

type ClusterMapping

type ClusterMapping struct {
	Name    string `yson:"name"`
	Cluster string `yson:"cluster"`
	Default bool   `yson:"default"`
}

type CommonServer

type CommonServer struct {
	BasicServer
	TimestampProviders TimestampProviders `yson:"timestamp_provider"`
	ClusterConnection  ClusterConnection  `yson:"cluster_connection"`
	CypressAnnotations map[string]any     `yson:"cypress_annotations,omitempty"`
}

type ConfigFormat

type ConfigFormat string

type ControllerAgent

type ControllerAgent struct {
	EnableTmpfs                  bool `yson:"enable_tmpfs"`
	UseColumnarStatisticsDefault bool `yson:"use_columnar_statistics_default"`
}

type ControllerAgentServer

type ControllerAgentServer struct {
	CommonServer
	ControllerAgent ControllerAgent `yson:"controller_agent"`
}

type Coordinator

type Coordinator struct {
	Enable            bool   `yson:"enable"`
	DefaultRoleFilter string `yson:"default_role_filter"`
}

type CriExecutor

type CriExecutor struct {
	RetryingChannel

	RuntimeEndpoint string        `yson:"runtime_endpoint,omitempty"`
	ImageEndpoint   string        `yson:"image_endpoint,omitempty"`
	Namespace       string        `yson:"namespace"`
	BaseCgroup      string        `yson:"base_cgroup"`
	RuntimeHandler  string        `yson:"runtime_handler,omitempty"`
	CpuPeriod       yson.Duration `yson:"cpu_period,omitempty"`
}

type CriJobEnvironment

type CriJobEnvironment struct {
	CriExecutor          *CriExecutor `yson:"cri_executor,omitempty"`
	JobProxyImage        string       `yson:"job_proxy_image,omitempty"`
	JobProxyBindMounts   []BindMount  `yson:"job_proxy_bind_mounts,omitempty"`
	UseJobProxyFromImage *bool        `yson:"use_job_proxy_from_image,omitempty"`
}

type CypressCookieManager

type CypressCookieManager struct{}

type CypressManager

type CypressManager struct {
	DefaultTableReplicationFactor   int `yson:"default_table_replication_factor,omitempty"`
	DefaultFileReplicationFactor    int `yson:"default_file_replication_factor,omitempty"`
	DefaultJournalReplicationFactor int `yson:"default_journal_replication_factor,omitempty"`
	DefaultJournalReadQuorum        int `yson:"default_journal_read_quorum,omitempty"`
	DefaultJournalWriteQuorum       int `yson:"default_journal_write_quorum,omitempty"`
}

type CypressTokenAuthenticator

type CypressTokenAuthenticator struct {
	Secure bool `yson:"secure"`
}

type CypressUserManager

type CypressUserManager struct{}

type DataNode

type DataNode struct {
	StoreLocations []StoreLocation `yson:"store_locations"`
	CacheLocations []CacheLocation `yson:"cache_locations"`
	BlockCache     BlockCache      `yson:"block_cache"`
	BlocksExtCache Cache           `yson:"blocks_ext_cache"`
	ChunkMetaCache Cache           `yson:"chunk_meta_cache"`
	BlockMetaCache Cache           `yson:"block_meta_cache"`
}

type DataNodeServer

type DataNodeServer struct {
	NodeServer
	DataNode DataNode `yson:"data_node"`
}

type Discovery

type Discovery struct {
	// Unfortunately AddressList is not applicable here, since
	// config field is named differently.
	Addresses []string `yson:"server_addresses"`
}

type DiscoveryConnection

type DiscoveryConnection struct {
	AddressList
}

type DiscoveryServer

type DiscoveryServer struct {
	CommonServer
	DiscoveryServer Discovery `yson:"discovery_server"`
}

type Driver

type Driver struct {
	TimestampProviders TimestampProviders `yson:"timestamp_provider,omitempty"`
	PrimaryMaster      MasterCell         `yson:"primary_master,omitempty"`
	APIVersion         int                `yson:"api_version,omitempty"`
}

type EncryptionMode

type EncryptionMode string
const (
	EncryptionModeDisabled EncryptionMode = "disabled"
	EncryptionModeOptional EncryptionMode = "optional"
	EncryptionModeRequired EncryptionMode = "required"
)

type ExecNode

type ExecNode struct {
	SlotManager   SlotManager   `yson:"slot_manager"`
	GpuManager    GpuManager    `yson:"gpu_manager"`
	JobController JobController `yson:"job_controller"`
	JobProxy      JobProxy      `yson:"job_proxy"`

	JobProxyAuthenticationManagerLegacy  *Auth    `yson:"job_proxy_authentication_manager,omitempty"`
	JobProxyLoggingLegacy                *Logging `yson:"job_proxy_logging,omitempty"`
	DoNotSetUserIdLegacy                 *bool    `yson:"do_not_set_user_id,omitempty"`
	ForwardAllEnvironmentVariablesLegacy *bool    `yson:"forward_all_environment_variables,omitempty"`

	// NOTE: Non-legacy "use_artifact_binds" moved into dynamic config.
	UseArtifactBindsLegacy *bool `yson:"use_artifact_binds,omitempty"`
}

type ExecNodeServer

type ExecNodeServer struct {
	NodeServer
	JobResourceManager   JobResourceManager `yson:"job_resource_manager"`
	ExecNode             ExecNode           `yson:"exec_node"`
	DataNode             DataNode           `yson:"data_node"`
	TabletNode           TabletNode         `yson:"tablet_node"`
	CachingObjectService Cache              `yson:"caching_object_service"`
}

type GatewayConfig

type GatewayConfig struct {
	MRJobBinary    string           `yson:"mr_job_bin"`
	UDFDirectory   string           `yson:"mr_job_udfs_dir"`
	ClusterMapping []ClusterMapping `yson:"cluster_mapping"`
}

type Generator

type Generator struct {
	BaseGenerator
	// contains filtered or unexported fields
}

func NewGenerator

func NewGenerator(
	ytsaurus *ytv1.Ytsaurus,
	clusterDomain string,
) *Generator

func (*Generator) GetChytInitClusterConfig

func (g *Generator) GetChytInitClusterConfig() ([]byte, error)

func (*Generator) GetClusterConnection

func (g *Generator) GetClusterConnection() ([]byte, error)

func (*Generator) GetControllerAgentConfig

func (g *Generator) GetControllerAgentConfig(spec *ytv1.ControllerAgentsSpec) ([]byte, error)

func (*Generator) GetDiscoveryConfig

func (g *Generator) GetDiscoveryConfig(spec *ytv1.DiscoverySpec) ([]byte, error)

func (*Generator) GetHTTPProxiesAddress

func (g *Generator) GetHTTPProxiesAddress(role string) string

func (*Generator) GetHTTPProxiesHeadlessServiceName

func (g *Generator) GetHTTPProxiesHeadlessServiceName(role string) string

func (*Generator) GetHTTPProxiesServiceAddress

func (g *Generator) GetHTTPProxiesServiceAddress(role string) string

func (*Generator) GetHTTPProxiesServiceName

func (g *Generator) GetHTTPProxiesServiceName(role string) string

func (*Generator) GetHTTPProxiesStatefulSetName

func (g *Generator) GetHTTPProxiesStatefulSetName(role string) string

func (*Generator) GetHTTPProxyConfig

func (g *Generator) GetHTTPProxyConfig(spec ytv1.HTTPProxiesSpec) ([]byte, error)

func (*Generator) GetMasterCachesConfig

func (g *Generator) GetMasterCachesConfig(spec *ytv1.MasterCachesSpec) ([]byte, error)

func (*Generator) GetMasterConfig

func (g *Generator) GetMasterConfig(spec *ytv1.MastersSpec) ([]byte, error)

func (*Generator) GetNativeClientConfig

func (g *Generator) GetNativeClientConfig() ([]byte, error)

func (*Generator) GetQueryTrackerConfig

func (g *Generator) GetQueryTrackerConfig(spec *ytv1.QueryTrackerSpec) ([]byte, error)

func (*Generator) GetQueryTrackerServiceName

func (g *Generator) GetQueryTrackerServiceName() string

func (*Generator) GetQueryTrackerStatefulSetName

func (g *Generator) GetQueryTrackerStatefulSetName() string

func (*Generator) GetQueueAgentAddresses

func (g *Generator) GetQueueAgentAddresses() []string

func (*Generator) GetQueueAgentConfig

func (g *Generator) GetQueueAgentConfig(spec *ytv1.QueueAgentSpec) ([]byte, error)

func (*Generator) GetQueueAgentPodNames

func (g *Generator) GetQueueAgentPodNames() []string

func (*Generator) GetQueueAgentServiceName

func (g *Generator) GetQueueAgentServiceName() string

func (*Generator) GetQueueAgentStatefulSetName

func (g *Generator) GetQueueAgentStatefulSetName() string

func (*Generator) GetRPCProxiesHeadlessServiceName

func (g *Generator) GetRPCProxiesHeadlessServiceName(role string) string

func (*Generator) GetRPCProxiesServiceName

func (g *Generator) GetRPCProxiesServiceName(role string) string

func (*Generator) GetRPCProxiesStatefulSetName

func (g *Generator) GetRPCProxiesStatefulSetName(role string) string

func (*Generator) GetRPCProxyConfig

func (g *Generator) GetRPCProxyConfig(spec ytv1.RPCProxiesSpec) ([]byte, error)

func (*Generator) GetSchedulerConfig

func (g *Generator) GetSchedulerConfig(spec *ytv1.SchedulersSpec) ([]byte, error)

func (*Generator) GetSchedulerServiceName

func (g *Generator) GetSchedulerServiceName() string

func (*Generator) GetSchedulerStatefulSetName

func (g *Generator) GetSchedulerStatefulSetName() string

func (*Generator) GetStrawberryControllerConfig

func (g *Generator) GetStrawberryControllerConfig() ([]byte, error)

func (*Generator) GetStrawberryControllerHeadlessServiceName

func (g *Generator) GetStrawberryControllerHeadlessServiceName() string

func (*Generator) GetStrawberryControllerServiceAddress

func (g *Generator) GetStrawberryControllerServiceAddress() string

func (*Generator) GetTCPProxiesHeadlessServiceName

func (g *Generator) GetTCPProxiesHeadlessServiceName(role string) string

func (*Generator) GetTCPProxiesServiceName

func (g *Generator) GetTCPProxiesServiceName(role string) string

func (*Generator) GetTCPProxiesStatefulSetName

func (g *Generator) GetTCPProxiesStatefulSetName(role string) string

func (*Generator) GetTCPProxyConfig

func (g *Generator) GetTCPProxyConfig(spec ytv1.TCPProxiesSpec) ([]byte, error)

func (*Generator) GetUIClustersConfig

func (g *Generator) GetUIClustersConfig() ([]byte, error)

func (*Generator) GetUICustomConfig

func (g *Generator) GetUICustomConfig() ([]byte, error)

func (*Generator) GetYQLAgentAddresses

func (g *Generator) GetYQLAgentAddresses() []string

func (*Generator) GetYQLAgentConfig

func (g *Generator) GetYQLAgentConfig(spec *ytv1.YQLAgentSpec) ([]byte, error)

func (*Generator) GetYQLAgentPodNames

func (g *Generator) GetYQLAgentPodNames() []string

func (*Generator) GetYQLAgentServiceName

func (g *Generator) GetYQLAgentServiceName() string

func (*Generator) GetYQLAgentStatefulSetName

func (g *Generator) GetYQLAgentStatefulSetName() string

type GeneratorDescriptor

type GeneratorDescriptor struct {
	// F must generate config in YSON.
	F YsonGeneratorFunc
	// Fmt is the desired serialization format for config map.
	// Note that conversion from YSON to Fmt (if needed) is performed as a very last
	// step of config generation pipeline.
	Fmt ConfigFormat
}

type GpuInfoSource

type GpuInfoSource struct {
	Type GpuInfoSourceType `yson:"type"`
}

type GpuInfoSourceType

type GpuInfoSourceType string
const (
	GpuInfoSourceTypeNvGpuManager GpuInfoSourceType = "nv_gpu_manager"
	GpuInfoSourceTypeNvidiaSmi    GpuInfoSourceType = "nvidia_smi"
)

type GpuManager

type GpuManager struct {
	GpuInfoSource GpuInfoSource `yson:"gpu_info_source"`
}

type HTTPProxyServer

type HTTPProxyServer struct {
	CommonServer
	Port        int          `yson:"port"`
	Auth        Auth         `yson:"auth"`
	Coordinator Coordinator  `yson:"coordinator"`
	Driver      Driver       `yson:"driver"`
	Role        string       `yson:"role"`
	HTTPSServer *HTTPSServer `yson:"https_server,omitempty"`
}

type HTTPSServer

type HTTPSServer struct {
	HTTPServer
	Credentials HTTPSServerCredentials `yson:"credentials"`
}

type HTTPSServerCredentials

type HTTPSServerCredentials struct {
	CertChain    PemBlob       `yson:"cert_chain,omitempty"`
	PrivateKey   PemBlob       `yson:"private_key,omitempty"`
	UpdatePeriod yson.Duration `yson:"update_period,omitempty"`
}

type HTTPServer

type HTTPServer struct {
	Port int `yson:"port"`
}

type HydraManager

type HydraManager struct {
	MaxChangelogCountToKeep int `yson:"max_changelog_count_to_keep"`
	MaxSnapshotCountToKeep  int `yson:"max_snapshot_count_to_keep"`
}

type HydraPeer

type HydraPeer struct {
	Address string `yson:"address"`
	Voting  bool   `yson:"voting"`
}

type IOEngine

type IOEngine struct {
	EnableSync *bool `yson:"enable_sync,omitempty"`
}

type JobController

type JobController struct {
	ResourceLimitsLegacy *JobResourceLimits `yson:"resource_limits,omitempty"`
	GpuManagerLegacy     *GpuManager        `yson:"gpu_manager,omitempty"`
}

type JobEnvironment

type JobEnvironment struct {
	Type     JobEnvironmentType `yson:"type,omitempty"`
	StartUID int                `yson:"start_uid,omitempty"`

	// FIXME(khlebnikov): Add "inline" tag into yson or remove polymorphism in config.
	CriJobEnvironment
}

type JobEnvironmentType

type JobEnvironmentType string
const (
	JobEnvironmentTypeSimple JobEnvironmentType = "simple"
	JobEnvironmentTypePorto  JobEnvironmentType = "porto"
	JobEnvironmentTypeCRI    JobEnvironmentType = "cri"
)

type JobProxy

type JobProxy struct {
	JobProxyAuthenticationManager  Auth    `yson:"job_proxy_authentication_manager"`
	JobProxyLogging                Logging `yson:"job_proxy_logging"`
	ForwardAllEnvironmentVariables *bool   `yson:"forward_all_environment_variables,omitempty"`
}

type JobResourceLimits

type JobResourceLimits struct {
	UserSlots *int `yson:"user_slots,omitempty"`
}

type JobResourceManager

type JobResourceManager struct {
	ResourceLimits JobResourceLimits `yson:"resource_limits"`
}

type LogFamily

type LogFamily string
const (
	LogFamilyPlainText  LogFamily = "plain_text"
	LogFamilyStructured LogFamily = "structured"
)

type Logging

type Logging struct {
	Writers map[string]LoggingWriter `yson:"writers"`
	Rules   []LoggingRule            `yson:"rules"`

	FlushPeriod int `yson:"flush_period"`
}

type LoggingRule

type LoggingRule struct {
	ExcludeCategories []string      `yson:"exclude_categories,omitempty"`
	IncludeCategories []string      `yson:"include_categories,omitempty"`
	MinLevel          ytv1.LogLevel `yson:"min_level,omitempty"`
	Writers           []string      `yson:"writers,omitempty"`
	Family            *LogFamily    `yson:"family,omitempty"`
}

type LoggingWriter

type LoggingWriter struct {
	WriterType ytv1.LogWriterType `yson:"type,omitempty"`
	FileName   string             `yson:"file_name,omitempty"`
	Format     ytv1.LogFormat     `yson:"format,omitempty"`

	CompressionMethod    string `yson:"compression_method,omitempty"`
	EnableCompression    bool   `yson:"enable_compression,omitempty"`
	UseTimestampSuffix   bool   `yson:"use_timestamp_suffix,omitempty"`
	EnableSystemMessages bool   `yson:"enable_system_messages,omitempty"`

	RotationPolicy *ytv1.LogRotationPolicy `yson:"rotation_policy,omitempty"`
}

type MasterCache

type MasterCache struct {
	AddressList
	CellID                    string `yson:"cell_id"`
	EnableMasterCacheDiscover bool   `yson:"enable_master_cache_discovery"`
}

type MasterCacheServer

type MasterCacheServer struct {
	CommonServer
}

type MasterCell

type MasterCell struct {
	AddressList
	Peers  []HydraPeer `yson:"peers"`
	CellID string      `yson:"cell_id"`
}

type MasterChangelogs

type MasterChangelogs struct {
	Path     string    `yson:"path"`
	IOEngine *IOEngine `yson:"io_engine,omitempty"`
}

type MasterServer

type MasterServer struct {
	CommonServer
	Snapshots        MasterSnapshots  `yson:"snapshots"`
	Changelogs       MasterChangelogs `yson:"changelogs"`
	UseNewHydra      bool             `yson:"use_new_hydra"`
	HydraManager     HydraManager     `yson:"hydra_manager"`
	CypressManager   CypressManager   `yson:"cypress_manager"`
	PrimaryMaster    MasterCell       `yson:"primary_master"`
	SecondaryMasters []MasterCell     `yson:"secondary_masters"`
}

type MasterSnapshots

type MasterSnapshots struct {
	Path string `yson:"path"`
}

type NativeClient

type NativeClient struct {
	AddressResolver AddressResolver `yson:"address_resolver"`
	Logging         Logging         `yson:"logging"`
	Driver          Driver          `yson:"driver"`
}

type NodeFlavor

type NodeFlavor string
const (
	NodeFlavorData   NodeFlavor = "data"
	NodeFlavorExec   NodeFlavor = "exec"
	NodeFlavorTablet NodeFlavor = "tablet"
)

type NodeGenerator

type NodeGenerator struct {
	BaseGenerator
}

func NewLocalNodeGenerator

func NewLocalNodeGenerator(
	ytsaurus *ytv1.Ytsaurus,
	clusterDomain string,
) *NodeGenerator

func NewRemoteNodeGenerator

func NewRemoteNodeGenerator(
	key types.NamespacedName,
	clusterDomain string,
	commonSpec ytv1.CommonSpec,
	masterConnectionSpec ytv1.MasterConnectionSpec,
	masterCachesSpec *ytv1.MasterCachesSpec,
) *NodeGenerator

func (*NodeGenerator) GetContainerdConfig

func (g *NodeGenerator) GetContainerdConfig(spec *ytv1.ExecNodesSpec) ([]byte, error)

func (*NodeGenerator) GetDataNodeConfig

func (g *NodeGenerator) GetDataNodeConfig(spec ytv1.DataNodesSpec) ([]byte, error)

func (*NodeGenerator) GetDataNodesServiceName

func (g *NodeGenerator) GetDataNodesServiceName(name string) string

func (*NodeGenerator) GetDataNodesStatefulSetName

func (g *NodeGenerator) GetDataNodesStatefulSetName(name string) string

func (*NodeGenerator) GetExecNodeConfig

func (g *NodeGenerator) GetExecNodeConfig(spec ytv1.ExecNodesSpec) ([]byte, error)

func (*NodeGenerator) GetExecNodesServiceName

func (g *NodeGenerator) GetExecNodesServiceName(name string) string

func (*NodeGenerator) GetExecNodesStatefulSetName

func (g *NodeGenerator) GetExecNodesStatefulSetName(name string) string

func (*NodeGenerator) GetTabletNodeConfig

func (g *NodeGenerator) GetTabletNodeConfig(spec ytv1.TabletNodesSpec) ([]byte, error)

func (*NodeGenerator) GetTabletNodesServiceName

func (g *NodeGenerator) GetTabletNodesServiceName(name string) string

func (*NodeGenerator) GetTabletNodesStatefulSetName

func (g *NodeGenerator) GetTabletNodesStatefulSetName(name string) string

type NodeServer

type NodeServer struct {
	CommonServer
	Flavors        []NodeFlavor   `yson:"flavors"`
	ResourceLimits ResourceLimits `yson:"resource_limits,omitempty"`
	Tags           []string       `yson:"tags,omitempty"`
	Rack           string         `yson:"rack,omitempty"`
	SkynetHttpPort int32          `yson:"skynet_http_port"`
}

type OauthCookieAuthenticator

type OauthCookieAuthenticator struct{}

type OauthService

type OauthService struct {
	Host               string  `yson:"host"`
	Port               int     `yson:"port"`
	Secure             bool    `yson:"secure"`
	UserInfoEndpoint   string  `yson:"user_info_endpoint"`
	UserInfoLoginField string  `yson:"user_info_login_field"`
	UserInfoErrorField *string `yson:"user_info_error_field,omitempty"`
}

type OauthTokenAuthenticator

type OauthTokenAuthenticator struct{}

type OperationsCleaner

type OperationsCleaner struct {
	EnableOperationArchivation *bool `yson:"enable_operation_archivation,omitempty"`
}

type PemBlob

type PemBlob struct {
	FileName string `yson:"file_name,omitempty"`
	Value    string `yson:"value,omitempty"`
}

type QueryTrackerServer

type QueryTrackerServer struct {
	CommonServer
	User                       string `yson:"user"`
	CreateStateTablesOnStartup bool   `yson:"create_state_tables_on_startup"`
}

type QueueAgent

type QueueAgent struct {
	Stage string `yson:"stage"`
}

type QueueAgentServer

type QueueAgentServer struct {
	CommonServer
	User       string     `yson:"user"`
	QueueAgent QueueAgent `yson:"queue_agent"`
}

type RPCProxyServer

type RPCProxyServer struct {
	CommonServer
	Role                      string                    `yson:"role"`
	CypressUserManager        CypressUserManager        `yson:"cypress_user_manager"`
	CypressTokenAuthenticator CypressTokenAuthenticator `yson:"cypress_token_authenticator"`
	OauthService              *OauthService             `yson:"oauth_service,omitempty"`
	OauthTokenAuthenticator   *OauthTokenAuthenticator  `yson:"oauth_token_authenticator,omitempty"`
	RequireAuthentication     *bool                     `yson:"require_authentication,omitempty"`
}

type ResourceLimits

type ResourceLimits struct {
	TotalMemory      int64    `yson:"total_memory,omitempty"`
	TotalCpu         *float32 `yson:"total_cpu,omitempty"`
	NodeDedicatedCpu *float32 `yson:"node_dedicated_cpu,omitempty"`
}

type RetryingChannel

type RetryingChannel struct {
	RetryBackoffTime yson.Duration `yson:"retry_backoff_time,omitempty"`
	RetryAttempts    int32         `yson:"retry_attempts,omitempty"`
	RetryTimeout     yson.Duration `yson:"retry_timeout,omitempty"`
}

type Scheduler

type Scheduler struct {
	OperationsCleaner OperationsCleaner `yson:"operations_cleaner"`
}

type SchedulerServer

type SchedulerServer struct {
	CommonServer
	Scheduler Scheduler `yson:"scheduler"`
}

type SlotLocation

type SlotLocation struct {
	Path               string `yson:"path"`
	MediumName         string `yson:"medium_name"`
	DiskQuota          *int64 `yson:"disk_quota,omitempty"`
	DiskUsageWatermark *int64 `yson:"disk_usage_watermark,omitempty"`
	EnableDiskQuota    *bool  `yson:"enable_disk_quota,omitempty"`
}

type SlotManager

type SlotManager struct {
	Locations      []SlotLocation `yson:"locations"`
	JobEnvironment JobEnvironment `yson:"job_environment"`

	DoNotSetUserId      *bool `yson:"do_not_set_user_id,omitempty"`
	EnableTmpfs         *bool `yson:"enable_tmpfs,omitempty"`
	DetachedTmpfsUmount *bool `yson:"detached_tmpfs_umount,omitempty"`
}

type StoreLocation

type StoreLocation struct {
	Path                   string    `yson:"path"`
	IOEngine               *IOEngine `yson:"io_config,omitempty"`
	MediumName             string    `yson:"medium_name"`
	Quota                  int64     `yson:"quota,omitempty"`
	HighWatermark          int64     `yson:"high_watermark,omitempty"`
	LowWatermark           int64     `yson:"low_watermark,omitempty"`
	DisableWritesWatermark int64     `yson:"disable_writes_watermark,omitempty"`
}

type Strawberry

type Strawberry struct {
	Root          string `yson:"root"`
	Stage         string `yson:"stage"`
	RobotUsername string `yson:"robot_username"`
}

type StrawberryController

type StrawberryController struct {
	LocationProxies     []string                 `yson:"location_proxies"`
	Strawberry          Strawberry               `yson:"strawberry"`
	Controllers         map[string]yson.RawValue `yson:"controllers"`
	HTTPAPIEndpoint     string                   `yson:"http_api_endpoint"`
	HTTPLocationAliases map[string][]string      `yson:"http_location_aliases"`
}

type TCPProxyServer

type TCPProxyServer struct {
	CommonServer
	Role string `yson:"role"`
}

type TabletNode

type TabletNode struct {
	VersionedChunkMetaCache Cache `yson:"versioned_chunk_meta_cache"`
}

type TabletNodeServer

type TabletNodeServer struct {
	NodeServer
	// TabletNode TabletNode `yson:"tablet_node"`
	CachingObjectService Cache `yson:"caching_object_service"`
}

type TimestampProviders

type TimestampProviders struct {
	AddressList
}

type UIAuthenticationType

type UIAuthenticationType string

type UICluster

type UICluster struct {
	ID             string               `yson:"id"`
	Name           string               `yson:"name"`
	Proxy          string               `yson:"proxy"`
	Secure         bool                 `yson:"secure"`
	Authentication UIAuthenticationType `yson:"authentication"`
	Group          string               `yson:"group"`
	Theme          string               `yson:"theme"`
	Environment    string               `yson:"environment"`
	Description    string               `yson:"description"`
	PrimaryMaster  UIPrimaryMaster      `yson:"primaryMaster"`
}

type UIClusters

type UIClusters struct {
	Clusters []UICluster `yson:"clusters"`
}

type UICustom

type UICustom struct {
	OdinBaseUrl *string `yson:"odinBaseUrl,omitempty"`
}

type UIPrimaryMaster

type UIPrimaryMaster struct {
	CellTag int16 `yson:"cellTag"`
}

type VerificationMode

type VerificationMode string
const (
	VerificationModeNone VerificationMode = "none"
	VerificationModeCa   VerificationMode = "ca"
	VerificationModeFull VerificationMode = "full"
)

type YQLAgent

type YQLAgent struct {
	GatewayConfig          GatewayConfig `yson:"gateway_config"`
	YqlPluginSharedLibrary string        `yson:"yql_plugin_shared_library"`
	YTTokenPath            string        `yson:"yt_token_path"`

	// For backward compatibility.
	MRJobBinary        string            `yson:"mr_job_binary"`
	UDFDirectory       string            `yson:"udf_directory"`
	AdditionalClusters map[string]string `yson:"additional_clusters"`
	DefaultCluster     string            `yson:"default_cluster"`
}

type YQLAgentServer

type YQLAgentServer struct {
	CommonServer
	User     string   `yson:"user"`
	YQLAgent YQLAgent `yson:"yql_agent"`
}

type YsonGeneratorFunc

type YsonGeneratorFunc func() ([]byte, error)

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL