terraform

package
v0.15.3 Latest Latest
Warning

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

Go to latest
Published: May 6, 2021 License: MPL-2.0 Imports: 40 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var EvalDataForNoInstanceKey = InstanceKeyEvalData{}

EvalDataForNoInstanceKey is a value of InstanceKeyData that sets no instance key values at all, suitable for use in contexts where no keyed instance is relevant.

View Source
var GraphTypeMap = map[string]GraphType{
	"apply":             GraphTypeApply,
	"plan":              GraphTypePlan,
	"plan-destroy":      GraphTypePlanDestroy,
	"plan-refresh-only": GraphTypePlanRefreshOnly,
	"validate":          GraphTypeValidate,
	"eval":              GraphTypeEval,
}

GraphTypeMap is a mapping of human-readable string to GraphType. This is useful to use as the mechanism for human input for configurable graph types.

Functions

func CheckCoreVersionRequirements added in v0.12.0

func CheckCoreVersionRequirements(config *configs.Config) tfdiags.Diagnostics

CheckCoreVersionRequirements visits each of the modules in the given configuration tree and verifies that any given Core version constraints match with the version of Terraform Core that is being used.

The returned diagnostics will contain errors if any constraints do not match. The returned diagnostics might also return warnings, which should be displayed to the user.

func GraphDot

func GraphDot(g *Graph, opts *dag.DotOpts) (string, error)

GraphDot returns the dot formatting of a visual representation of the given Terraform graph.

func ReferencesFromConfig added in v0.7.8

func ReferencesFromConfig(body hcl.Body, schema *configschema.Block) []*addrs.Reference

ReferencesFromConfig returns the references that a configuration has based on the interpolated variables in a configuration.

Types

type ApplyGraphBuilder added in v0.7.8

type ApplyGraphBuilder struct {
	// Config is the configuration tree that the diff was built from.
	Config *configs.Config

	// Changes describes the changes that we need apply.
	Changes *plans.Changes

	// State is the current state
	State *states.State

	// Components is a factory for the plug-in components (providers and
	// provisioners) available for use.
	Components contextComponentFactory

	// Schemas is the repository of schemas we will draw from to analyse
	// the configuration.
	Schemas *Schemas

	// Targets are resources to target. This is only required to make sure
	// unnecessary outputs aren't included in the apply graph. The plan
	// builder successfully handles targeting resources. In the future,
	// outputs should go into the diff so that this is unnecessary.
	Targets []addrs.Targetable

	// ForceReplace are the resource instance addresses that the user
	// requested to force replacement for when creating the plan, if any.
	// The apply step refers to these as part of verifying that the planned
	// actions remain consistent between plan and apply.
	ForceReplace []addrs.AbsResourceInstance

	// Validate will do structural validation of the graph.
	Validate bool
}

ApplyGraphBuilder implements GraphBuilder and is responsible for building a graph for applying a Terraform diff.

Because the graph is built from the diff (vs. the config or state), this helps ensure that the apply-time graph doesn't modify any resources that aren't explicitly in the diff. There are other scenarios where the diff can be deviated, so this is just one layer of protection.

func (*ApplyGraphBuilder) Build added in v0.7.8

See GraphBuilder

func (*ApplyGraphBuilder) Steps added in v0.7.8

func (b *ApplyGraphBuilder) Steps() []GraphTransformer

See GraphBuilder

type AttachDependenciesTransformer added in v0.12.14

type AttachDependenciesTransformer struct {
}

AttachDependenciesTransformer records all resource dependencies for each instance, and attaches the addresses to the node itself. Managed resource will record these in the state for proper ordering of destroy operations.

func (AttachDependenciesTransformer) Transform added in v0.12.14

func (t AttachDependenciesTransformer) Transform(g *Graph) error

type AttachResourceConfigTransformer added in v0.7.8

type AttachResourceConfigTransformer struct {
	Config *configs.Config // Config is the root node in the config tree
}

AttachResourceConfigTransformer goes through the graph and attaches resource configuration structures to nodes that implement GraphNodeAttachManagedResourceConfig or GraphNodeAttachDataResourceConfig.

The attached configuration structures are directly from the configuration. If they're going to be modified, a copy should be made.

func (*AttachResourceConfigTransformer) Transform added in v0.7.8

func (t *AttachResourceConfigTransformer) Transform(g *Graph) error

type AttachSchemaTransformer added in v0.12.0

type AttachSchemaTransformer struct {
	Schemas *Schemas
	Config  *configs.Config
}

AttachSchemaTransformer finds nodes that implement GraphNodeAttachResourceSchema, GraphNodeAttachProviderConfigSchema, or GraphNodeAttachProvisionerSchema, looks up the needed schemas for each and then passes them to a method implemented by the node.

func (*AttachSchemaTransformer) Transform added in v0.12.0

func (t *AttachSchemaTransformer) Transform(g *Graph) error

type AttachStateTransformer added in v0.7.8

type AttachStateTransformer struct {
	State *states.State // State is the root state
}

AttachStateTransformer goes through the graph and attaches state to nodes that implement the interfaces above.

func (*AttachStateTransformer) Transform added in v0.7.8

func (t *AttachStateTransformer) Transform(g *Graph) error

type BasicGraphBuilder added in v0.4.0

type BasicGraphBuilder struct {
	Steps    []GraphTransformer
	Validate bool
	// Optional name to add to the graph debug log
	Name string
}

BasicGraphBuilder is a GraphBuilder that builds a graph out of a series of transforms and (optionally) validates the graph is a valid structure.

func (*BasicGraphBuilder) Build added in v0.4.0

type BuiltinEvalContext added in v0.4.0

type BuiltinEvalContext struct {
	// StopContext is the context used to track whether we're complete
	StopContext context.Context

	// PathValue is the Path that this context is operating within.
	PathValue addrs.ModuleInstance

	// Evaluator is used for evaluating expressions within the scope of this
	// eval context.
	Evaluator *Evaluator

	// Schemas is a repository of all of the schemas we should need to
	// decode configuration blocks and expressions. This must be constructed by
	// the caller to include schemas for all of the providers, resource types,
	// data sources and provisioners used by the given configuration and
	// state.
	//
	// This must not be mutated during evaluation.
	Schemas *Schemas

	// VariableValues contains the variable values across all modules. This
	// structure is shared across the entire containing context, and so it
	// may be accessed only when holding VariableValuesLock.
	// The keys of the first level of VariableValues are the string
	// representations of addrs.ModuleInstance values. The second-level keys
	// are variable names within each module instance.
	VariableValues     map[string]map[string]cty.Value
	VariableValuesLock *sync.Mutex

	Components            contextComponentFactory
	Hooks                 []Hook
	InputValue            UIInput
	ProviderCache         map[string]providers.Interface
	ProviderInputConfig   map[string]map[string]cty.Value
	ProviderLock          *sync.Mutex
	ProvisionerCache      map[string]provisioners.Interface
	ProvisionerLock       *sync.Mutex
	ChangesValue          *plans.ChangesSync
	StateValue            *states.SyncState
	RefreshStateValue     *states.SyncState
	PrevRunStateValue     *states.SyncState
	InstanceExpanderValue *instances.Expander
	// contains filtered or unexported fields
}

BuiltinEvalContext is an EvalContext implementation that is used by Terraform by default.

func (*BuiltinEvalContext) Changes added in v0.12.0

func (ctx *BuiltinEvalContext) Changes() *plans.ChangesSync

func (*BuiltinEvalContext) CloseProvider added in v0.6.0

func (ctx *BuiltinEvalContext) CloseProvider(addr addrs.AbsProviderConfig) error

func (*BuiltinEvalContext) CloseProvisioners added in v0.15.0

func (ctx *BuiltinEvalContext) CloseProvisioners() error

func (*BuiltinEvalContext) ConfigureProvider added in v0.4.0

func (ctx *BuiltinEvalContext) ConfigureProvider(addr addrs.AbsProviderConfig, cfg cty.Value) tfdiags.Diagnostics

func (*BuiltinEvalContext) EvaluateBlock added in v0.12.0

func (ctx *BuiltinEvalContext) EvaluateBlock(body hcl.Body, schema *configschema.Block, self addrs.Referenceable, keyData InstanceKeyEvalData) (cty.Value, hcl.Body, tfdiags.Diagnostics)

func (*BuiltinEvalContext) EvaluateExpr added in v0.12.0

func (ctx *BuiltinEvalContext) EvaluateExpr(expr hcl.Expression, wantType cty.Type, self addrs.Referenceable) (cty.Value, tfdiags.Diagnostics)

func (*BuiltinEvalContext) EvaluationScope added in v0.12.0

func (ctx *BuiltinEvalContext) EvaluationScope(self addrs.Referenceable, keyData InstanceKeyEvalData) *lang.Scope

func (*BuiltinEvalContext) GetVariableValue added in v0.12.20

func (ctx *BuiltinEvalContext) GetVariableValue(addr addrs.AbsInputVariableInstance) cty.Value

func (*BuiltinEvalContext) Hook added in v0.4.0

func (ctx *BuiltinEvalContext) Hook(fn func(Hook) (HookAction, error)) error

func (*BuiltinEvalContext) InitProvider added in v0.4.0

func (*BuiltinEvalContext) Input added in v0.4.0

func (ctx *BuiltinEvalContext) Input() UIInput

func (*BuiltinEvalContext) InstanceExpander added in v0.13.0

func (ctx *BuiltinEvalContext) InstanceExpander() *instances.Expander

func (*BuiltinEvalContext) Path added in v0.4.0

func (*BuiltinEvalContext) PrevRunState added in v0.15.3

func (ctx *BuiltinEvalContext) PrevRunState() *states.SyncState

func (*BuiltinEvalContext) Provider added in v0.4.0

func (*BuiltinEvalContext) ProviderInput added in v0.4.0

func (ctx *BuiltinEvalContext) ProviderInput(pc addrs.AbsProviderConfig) map[string]cty.Value

func (*BuiltinEvalContext) ProviderSchema added in v0.12.0

func (ctx *BuiltinEvalContext) ProviderSchema(addr addrs.AbsProviderConfig) *ProviderSchema

func (*BuiltinEvalContext) Provisioner added in v0.4.0

func (ctx *BuiltinEvalContext) Provisioner(n string) (provisioners.Interface, error)

func (*BuiltinEvalContext) ProvisionerSchema added in v0.12.0

func (ctx *BuiltinEvalContext) ProvisionerSchema(n string) *configschema.Block

func (*BuiltinEvalContext) RefreshState added in v0.14.0

func (ctx *BuiltinEvalContext) RefreshState() *states.SyncState

func (*BuiltinEvalContext) SetModuleCallArguments added in v0.12.0

func (ctx *BuiltinEvalContext) SetModuleCallArguments(n addrs.ModuleCallInstance, vals map[string]cty.Value)

func (*BuiltinEvalContext) SetProviderInput added in v0.4.0

func (ctx *BuiltinEvalContext) SetProviderInput(pc addrs.AbsProviderConfig, c map[string]cty.Value)

func (*BuiltinEvalContext) State added in v0.4.0

func (ctx *BuiltinEvalContext) State() *states.SyncState

func (*BuiltinEvalContext) Stopped added in v0.9.0

func (ctx *BuiltinEvalContext) Stopped() <-chan struct{}

func (*BuiltinEvalContext) WithPath added in v0.13.0

func (ctx *BuiltinEvalContext) WithPath(path addrs.ModuleInstance) EvalContext

type CBDEdgeTransformer added in v0.7.8

type CBDEdgeTransformer struct {
	// Module and State are only needed to look up dependencies in
	// any way possible. Either can be nil if not availabile.
	Config *configs.Config
	State  *states.State

	// If configuration is present then Schemas is required in order to
	// obtain schema information from providers and provisioners so we can
	// properly resolve implicit dependencies.
	Schemas *Schemas
}

CBDEdgeTransformer modifies the edges of CBD nodes that went through the DestroyEdgeTransformer to have the right dependencies. There are two real tasks here:

  1. With CBD, the destroy edge is inverted: the destroy depends on the creation.

  2. A_d must depend on resources that depend on A. This is to enable the destroy to only happen once nodes that depend on A successfully update to A. Example: adding a web server updates the load balancer before deleting the old web server.

This transformer requires that a previous transformer has already forced create_before_destroy on for nodes that are depended on by explicit CBD nodes. This is the logic in ForcedCBDTransformer, though in practice we will get here by recording the CBD-ness of each change in the plan during the plan walk and then forcing the nodes into the appropriate setting during DiffTransformer when building the apply graph.

func (*CBDEdgeTransformer) Transform added in v0.7.8

func (t *CBDEdgeTransformer) Transform(g *Graph) error

type CallbackUIOutput added in v0.3.0

type CallbackUIOutput struct {
	OutputFn func(string)
}

func (*CallbackUIOutput) Output added in v0.4.0

func (o *CallbackUIOutput) Output(v string)

type CloseProviderTransformer added in v0.6.0

type CloseProviderTransformer struct{}

CloseProviderTransformer is a GraphTransformer that adds nodes to the graph that will close open provider connections that aren't needed anymore. A provider connection is not needed anymore once all depended resources in the graph are evaluated.

func (*CloseProviderTransformer) Transform added in v0.6.0

func (t *CloseProviderTransformer) Transform(g *Graph) error

type CloseRootModuleTransformer added in v0.13.0

type CloseRootModuleTransformer struct{}

CloseRootModuleTransformer is a GraphTransformer that adds a root to the graph.

func (*CloseRootModuleTransformer) Transform added in v0.13.0

func (t *CloseRootModuleTransformer) Transform(g *Graph) error

type ConcreteModuleNodeFunc added in v0.13.0

type ConcreteModuleNodeFunc func(n *nodeExpandModule) dag.Vertex

type ConcreteProviderNodeFunc added in v0.8.0

type ConcreteProviderNodeFunc func(*NodeAbstractProvider) dag.Vertex

ConcreteProviderNodeFunc is a callback type used to convert an abstract provider to a concrete one of some type.

type ConcreteResourceInstanceDeposedNodeFunc added in v0.12.0

type ConcreteResourceInstanceDeposedNodeFunc func(*NodeAbstractResourceInstance, states.DeposedKey) dag.Vertex

ConcreteResourceInstanceDeposedNodeFunc is a callback type used to convert an abstract resource instance to a concrete one of some type that has an associated deposed object key.

type ConcreteResourceInstanceNodeFunc added in v0.12.0

type ConcreteResourceInstanceNodeFunc func(*NodeAbstractResourceInstance) dag.Vertex

ConcreteResourceInstanceNodeFunc is a callback type used to convert an abstract resource instance to a concrete one of some type.

type ConcreteResourceNodeFunc added in v0.7.8

type ConcreteResourceNodeFunc func(*NodeAbstractResource) dag.Vertex

ConcreteResourceNodeFunc is a callback type used to convert an abstract resource to a concrete one of some type.

type ConfigTransformer added in v0.4.0

type ConfigTransformer struct {
	Concrete ConcreteResourceNodeFunc

	// Module is the module to add resources from.
	Config *configs.Config

	// Mode will only add resources that match the given mode
	ModeFilter bool
	Mode       addrs.ResourceMode
}

ConfigTransformer is a GraphTransformer that adds all the resources from the configuration to the graph.

The module used to configure this transformer must be the root module.

Only resources are added to the graph. Variables, outputs, and providers must be added via other transforms.

Unlike ConfigTransformerOld, this transformer creates a graph with all resources including module resources, rather than creating module nodes that are then "flattened".

func (*ConfigTransformer) Transform added in v0.4.0

func (t *ConfigTransformer) Transform(g *Graph) error

type Context

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

Context represents all the context that Terraform needs in order to perform operations on infrastructure. This structure is built using NewContext.

func NewContext

func NewContext(opts *ContextOpts) (*Context, tfdiags.Diagnostics)

NewContext creates a new Context structure.

Once a Context is created, the caller must not access or mutate any of the objects referenced (directly or indirectly) by the ContextOpts fields.

If the returned diagnostics contains errors then the resulting context is invalid and must not be used.

func (*Context) Apply

func (c *Context) Apply() (*states.State, tfdiags.Diagnostics)

Apply applies the changes represented by this context and returns the resulting state.

Even in the case an error is returned, the state may be returned and will potentially be partially updated. In addition to returning the resulting state, this context is updated with the latest state.

If the state is required after an error, the caller should call Context.State, rather than rely on the return value.

TODO: Apply and Refresh should either always return a state, or rely on the

State() method. Currently the helper/resource testing framework relies
on the absence of a returned state to determine if Destroy can be
called, so that will need to be refactored before this can be changed.

func (*Context) Config added in v0.12.0

func (c *Context) Config() *configs.Config

Config returns the configuration tree associated with this context.

func (*Context) Eval added in v0.12.0

Eval produces a scope in which expressions can be evaluated for the given module path.

This method must first evaluate any ephemeral values (input variables, local values, and output values) in the configuration. These ephemeral values are not included in the persisted state, so they must be re-computed using other values in the state before they can be properly evaluated. The updated values are retained in the main state associated with the receiving context.

This function takes no action against remote APIs but it does need access to all provider and provisioner instances in order to obtain their schemas for type checking.

The result is an evaluation scope that can be used to resolve references against the root module. If the returned diagnostics contains errors then the returned scope may be nil. If it is not nil then it may still be used to attempt expression evaluation or other analysis, but some expressions may not behave as expected.

func (*Context) Graph

func (c *Context) Graph(typ GraphType, opts *ContextGraphOpts) (*Graph, tfdiags.Diagnostics)

Graph returns the graph used for the given operation type.

The most extensive or complex graph type is GraphTypePlan.

func (*Context) Import added in v0.7.0

func (c *Context) Import(opts *ImportOpts) (*states.State, tfdiags.Diagnostics)

Import takes already-created external resources and brings them under Terraform management. Import requires the exact type, name, and ID of the resources to import.

This operation is idempotent. If the requested resource is already imported, no changes are made to the state.

Further, this operation also gracefully handles partial state. If during an import there is a failure, all previously imported resources remain imported.

func (*Context) Input added in v0.3.0

func (c *Context) Input(mode InputMode) tfdiags.Diagnostics

Input asks for input to fill unset required arguments in provider configurations.

This modifies the configuration in-place, so asking for Input twice may result in different UI output showing different current values.

func (*Context) Plan

func (c *Context) Plan() (*plans.Plan, tfdiags.Diagnostics)

Plan generates an execution plan for the given context, and returns the refreshed state.

The execution plan encapsulates the context and can be stored in order to reinstantiate a context later for Apply.

Plan also updates the diff of this context to be the diff generated by the plan, so Apply can be called after.

func (*Context) Refresh

func (c *Context) Refresh() (*states.State, tfdiags.Diagnostics)

Refresh goes through all the resources in the state and refreshes them to their latest state. This is done by executing a plan, and retaining the state while discarding the change set.

In the case of an error, there is no state returned.

func (*Context) Schemas added in v0.12.0

func (c *Context) Schemas() *Schemas

func (*Context) SetVariable added in v0.4.0

func (c *Context) SetVariable(k string, v cty.Value)

SetVariable sets a variable after a context has already been built.

func (*Context) State added in v0.9.0

func (c *Context) State() *states.State

State returns a copy of the current state associated with this context.

This cannot safely be called in parallel with any other Context function.

func (*Context) Stop

func (c *Context) Stop()

Stop stops the running task.

Stop will block until the task completes.

func (*Context) Validate

func (c *Context) Validate() tfdiags.Diagnostics

Validate performs semantic validation of the configuration, and returning any warnings or errors.

Syntax and structural checks are performed by the configuration loader, and so are not repeated here.

func (*Context) Variables added in v0.4.0

func (c *Context) Variables() InputValues

Variables will return the mapping of variables that were defined for this Context. If Input was called, this mapping may be different than what was given.

type ContextGraphOpts added in v0.5.0

type ContextGraphOpts struct {
	// If true, validates the graph structure (checks for cycles).
	Validate bool

	// Legacy graphs only: won't prune the graph
	Verbose bool
}

type ContextGraphWalker added in v0.4.0

type ContextGraphWalker struct {
	NullGraphWalker

	// Configurable values
	Context            *Context
	State              *states.SyncState   // Used for safe concurrent access to state
	RefreshState       *states.SyncState   // Used for safe concurrent access to state
	PrevRunState       *states.SyncState   // Used for safe concurrent access to state
	Changes            *plans.ChangesSync  // Used for safe concurrent writes to changes
	InstanceExpander   *instances.Expander // Tracks our gradual expansion of module and resource instances
	Operation          walkOperation
	StopContext        context.Context
	RootVariableValues InputValues

	// This is an output. Do not set this, nor read it while a graph walk
	// is in progress.
	NonFatalDiagnostics tfdiags.Diagnostics
	// contains filtered or unexported fields
}

ContextGraphWalker is the GraphWalker implementation used with the Context struct to walk and evaluate the graph.

func (*ContextGraphWalker) EnterPath added in v0.5.0

func (*ContextGraphWalker) EvalContext added in v0.13.0

func (w *ContextGraphWalker) EvalContext() EvalContext

func (*ContextGraphWalker) Execute added in v0.14.0

type ContextMeta added in v0.9.0

type ContextMeta struct {
	Env string // Env is the state environment

	// OriginalWorkingDir is the working directory where the Terraform CLI
	// was run from, which may no longer actually be the current working
	// directory if the user included the -chdir=... option.
	//
	// If this string is empty then the original working directory is the same
	// as the current working directory.
	//
	// In most cases we should respect the user's override by ignoring this
	// path and just using the current working directory, but this is here
	// for some exceptional cases where the original working directory is
	// needed.
	OriginalWorkingDir string
}

ContextMeta is metadata about the running context. This is information that this package or structure cannot determine on its own but exposes into Terraform in various ways. This must be provided by the Context initializer.

type ContextOpts

type ContextOpts struct {
	Config       *configs.Config
	Changes      *plans.Changes
	State        *states.State
	Targets      []addrs.Targetable
	ForceReplace []addrs.AbsResourceInstance
	Variables    InputValues
	Meta         *ContextMeta
	PlanMode     plans.Mode
	SkipRefresh  bool

	Hooks        []Hook
	Parallelism  int
	Providers    map[addrs.Provider]providers.Factory
	Provisioners map[string]provisioners.Factory

	// If non-nil, will apply as additional constraints on the provider
	// plugins that will be requested from the provider resolver.
	ProviderSHA256s map[string][]byte

	// If non-nil, will be verified to ensure that provider requirements from
	// configuration can be satisfied by the set of locked dependencies.
	LockedDependencies *depsfile.Locks

	// Set of providers to exclude from the requirements check process, as they
	// are marked as in local development.
	ProvidersInDevelopment map[addrs.Provider]struct{}

	UIInput UIInput
}

ContextOpts are the user-configurable options to create a context with NewContext.

type CountBoundaryTransformer added in v0.7.8

type CountBoundaryTransformer struct {
	Config *configs.Config
}

CountBoundaryTransformer adds a node that depends on everything else so that it runs last in order to clean up the state for nodes that are on the "count boundary": "foo.0" when only one exists becomes "foo"

func (*CountBoundaryTransformer) Transform added in v0.7.8

func (t *CountBoundaryTransformer) Transform(g *Graph) error

type DestroyEdgeTransformer added in v0.7.8

type DestroyEdgeTransformer struct {
	// These are needed to properly build the graph of dependencies
	// to determine what a destroy node depends on. Any of these can be nil.
	Config *configs.Config
	State  *states.State

	// If configuration is present then Schemas is required in order to
	// obtain schema information from providers and provisioners in order
	// to properly resolve implicit dependencies.
	Schemas *Schemas
}

DestroyEdgeTransformer is a GraphTransformer that creates the proper references for destroy resources. Destroy resources are more complex in that they must be depend on the destruction of resources that in turn depend on the CREATION of the node being destroy.

That is complicated. Visually:

B_d -> A_d -> A -> B

Notice that A destroy depends on B destroy, while B create depends on A create. They're inverted. This must be done for example because often dependent resources will block parent resources from deleting. Concrete example: VPC with subnets, the VPC can't be deleted while there are still subnets.

func (*DestroyEdgeTransformer) Transform added in v0.7.8

func (t *DestroyEdgeTransformer) Transform(g *Graph) error

type DestroyPlanGraphBuilder added in v0.7.8

type DestroyPlanGraphBuilder struct {
	// Config is the configuration tree to build the plan from.
	Config *configs.Config

	// State is the current state
	State *states.State

	// Components is a factory for the plug-in components (providers and
	// provisioners) available for use.
	Components contextComponentFactory

	// Schemas is the repository of schemas we will draw from to analyse
	// the configuration.
	Schemas *Schemas

	// Targets are resources to target
	Targets []addrs.Targetable

	// Validate will do structural validation of the graph.
	Validate bool
	// contains filtered or unexported fields
}

DestroyPlanGraphBuilder implements GraphBuilder and is responsible for planning a pure-destroy.

Planning a pure destroy operation is simple because we can ignore most ordering configuration and simply reverse the state. This graph mainly exists for targeting, because we need to walk the destroy dependencies to ensure we plan the required resources. Without the requirement for targeting, the plan could theoretically be created directly from the state.

func (*DestroyPlanGraphBuilder) Build added in v0.7.8

See GraphBuilder

func (*DestroyPlanGraphBuilder) Steps added in v0.7.8

See GraphBuilder

type DiffTransformer added in v0.7.8

type DiffTransformer struct {
	Concrete ConcreteResourceInstanceNodeFunc
	State    *states.State
	Changes  *plans.Changes
}

DiffTransformer is a GraphTransformer that adds graph nodes representing each of the resource changes described in the given Changes object.

func (*DiffTransformer) Transform added in v0.7.8

func (t *DiffTransformer) Transform(g *Graph) error

type EvalContext added in v0.4.0

type EvalContext interface {
	// Stopped returns a channel that is closed when evaluation is stopped
	// via Terraform.Context.Stop()
	Stopped() <-chan struct{}

	// Path is the current module path.
	Path() addrs.ModuleInstance

	// Hook is used to call hook methods. The callback is called for each
	// hook and should return the hook action to take and the error.
	Hook(func(Hook) (HookAction, error)) error

	// Input is the UIInput object for interacting with the UI.
	Input() UIInput

	// InitProvider initializes the provider with the given address, and returns
	// the implementation of the resource provider or an error.
	//
	// It is an error to initialize the same provider more than once. This
	// method will panic if the module instance address of the given provider
	// configuration does not match the Path() of the EvalContext.
	InitProvider(addr addrs.AbsProviderConfig) (providers.Interface, error)

	// Provider gets the provider instance with the given address (already
	// initialized) or returns nil if the provider isn't initialized.
	//
	// This method expects an _absolute_ provider configuration address, since
	// resources in one module are able to use providers from other modules.
	// InitProvider must've been called on the EvalContext of the module
	// that owns the given provider before calling this method.
	Provider(addrs.AbsProviderConfig) providers.Interface

	// ProviderSchema retrieves the schema for a particular provider, which
	// must have already been initialized with InitProvider.
	//
	// This method expects an _absolute_ provider configuration address, since
	// resources in one module are able to use providers from other modules.
	ProviderSchema(addrs.AbsProviderConfig) *ProviderSchema

	// CloseProvider closes provider connections that aren't needed anymore.
	//
	// This method will panic if the module instance address of the given
	// provider configuration does not match the Path() of the EvalContext.
	CloseProvider(addrs.AbsProviderConfig) error

	// ConfigureProvider configures the provider with the given
	// configuration. This is a separate context call because this call
	// is used to store the provider configuration for inheritance lookups
	// with ParentProviderConfig().
	//
	// This method will panic if the module instance address of the given
	// provider configuration does not match the Path() of the EvalContext.
	ConfigureProvider(addrs.AbsProviderConfig, cty.Value) tfdiags.Diagnostics

	// ProviderInput and SetProviderInput are used to configure providers
	// from user input.
	//
	// These methods will panic if the module instance address of the given
	// provider configuration does not match the Path() of the EvalContext.
	ProviderInput(addrs.AbsProviderConfig) map[string]cty.Value
	SetProviderInput(addrs.AbsProviderConfig, map[string]cty.Value)

	// Provisioner gets the provisioner instance with the given name.
	Provisioner(string) (provisioners.Interface, error)

	// ProvisionerSchema retrieves the main configuration schema for a
	// particular provisioner, which must have already been initialized with
	// InitProvisioner.
	ProvisionerSchema(string) *configschema.Block

	// CloseProvisioner closes all provisioner plugins.
	CloseProvisioners() error

	// EvaluateBlock takes the given raw configuration block and associated
	// schema and evaluates it to produce a value of an object type that
	// conforms to the implied type of the schema.
	//
	// The "self" argument is optional. If given, it is the referenceable
	// address that the name "self" should behave as an alias for when
	// evaluating. Set this to nil if the "self" object should not be available.
	//
	// The "key" argument is also optional. If given, it is the instance key
	// of the current object within the multi-instance container it belongs
	// to. For example, on a resource block with "count" set this should be
	// set to a different addrs.IntKey for each instance created from that
	// block. Set this to addrs.NoKey if not appropriate.
	//
	// The returned body is an expanded version of the given body, with any
	// "dynamic" blocks replaced with zero or more static blocks. This can be
	// used to extract correct source location information about attributes of
	// the returned object value.
	EvaluateBlock(body hcl.Body, schema *configschema.Block, self addrs.Referenceable, keyData InstanceKeyEvalData) (cty.Value, hcl.Body, tfdiags.Diagnostics)

	// EvaluateExpr takes the given HCL expression and evaluates it to produce
	// a value.
	//
	// The "self" argument is optional. If given, it is the referenceable
	// address that the name "self" should behave as an alias for when
	// evaluating. Set this to nil if the "self" object should not be available.
	EvaluateExpr(expr hcl.Expression, wantType cty.Type, self addrs.Referenceable) (cty.Value, tfdiags.Diagnostics)

	// EvaluationScope returns a scope that can be used to evaluate reference
	// addresses in this context.
	EvaluationScope(self addrs.Referenceable, keyData InstanceKeyEvalData) *lang.Scope

	// SetModuleCallArguments defines values for the variables of a particular
	// child module call.
	//
	// Calling this function multiple times has merging behavior, keeping any
	// previously-set keys that are not present in the new map.
	SetModuleCallArguments(addrs.ModuleCallInstance, map[string]cty.Value)

	// GetVariableValue returns the value provided for the input variable with
	// the given address, or cty.DynamicVal if the variable hasn't been assigned
	// a value yet.
	//
	// Most callers should deal with variable values only indirectly via
	// EvaluationScope and the other expression evaluation functions, but
	// this is provided because variables tend to be evaluated outside of
	// the context of the module they belong to and so we sometimes need to
	// override the normal expression evaluation behavior.
	GetVariableValue(addr addrs.AbsInputVariableInstance) cty.Value

	// Changes returns the writer object that can be used to write new proposed
	// changes into the global changes set.
	Changes() *plans.ChangesSync

	// State returns a wrapper object that provides safe concurrent access to
	// the global state.
	State() *states.SyncState

	// RefreshState returns a wrapper object that provides safe concurrent
	// access to the state used to store the most recently refreshed resource
	// values.
	RefreshState() *states.SyncState

	// PrevRunState returns a wrapper object that provides safe concurrent
	// access to the state which represents the result of the previous run,
	// updated only so that object data conforms to current schemas for
	// meaningful comparison with RefreshState.
	PrevRunState() *states.SyncState

	// InstanceExpander returns a helper object for tracking the expansion of
	// graph nodes during the plan phase in response to "count" and "for_each"
	// arguments.
	//
	// The InstanceExpander is a global object that is shared across all of the
	// EvalContext objects for a given configuration.
	InstanceExpander() *instances.Expander

	// WithPath returns a copy of the context with the internal path set to the
	// path argument.
	WithPath(path addrs.ModuleInstance) EvalContext
}

EvalContext is the interface that is given to eval nodes to execute.

type EvalGraphBuilder added in v0.12.0

type EvalGraphBuilder struct {
	// Config is the configuration tree.
	Config *configs.Config

	// State is the current state
	State *states.State

	// Components is a factory for the plug-in components (providers and
	// provisioners) available for use.
	Components contextComponentFactory

	// Schemas is the repository of schemas we will draw from to analyse
	// the configuration.
	Schemas *Schemas
}

EvalGraphBuilder implements GraphBuilder and constructs a graph suitable for evaluating in-memory values (input variables, local values, output values) in the state without any other side-effects.

This graph is used only in weird cases, such as the "terraform console" CLI command, where we need to evaluate expressions against the state without taking any other actions.

The generated graph will include nodes for providers, resources, etc just to allow indirect dependencies to be resolved, but these nodes will not take any actions themselves since we assume that their parts of the state, if any, are already complete.

Although the providers are never configured, they must still be available in order to obtain schema information used for type checking, etc.

func (*EvalGraphBuilder) Build added in v0.12.0

See GraphBuilder

func (*EvalGraphBuilder) Steps added in v0.12.0

func (b *EvalGraphBuilder) Steps() []GraphTransformer

See GraphBuilder

type Evaluator added in v0.12.0

type Evaluator struct {
	// Operation defines what type of operation this evaluator is being used
	// for.
	Operation walkOperation

	// Meta is contextual metadata about the current operation.
	Meta *ContextMeta

	// Config is the root node in the configuration tree.
	Config *configs.Config

	// VariableValues is a map from variable names to their associated values,
	// within the module indicated by ModulePath. VariableValues is modified
	// concurrently, and so it must be accessed only while holding
	// VariableValuesLock.
	//
	// The first map level is string representations of addr.ModuleInstance
	// values, while the second level is variable names.
	VariableValues     map[string]map[string]cty.Value
	VariableValuesLock *sync.Mutex

	// Schemas is a repository of all of the schemas we should need to
	// evaluate expressions. This must be constructed by the caller to
	// include schemas for all of the providers, resource types, data sources
	// and provisioners used by the given configuration and state.
	//
	// This must not be mutated during evaluation.
	Schemas *Schemas

	// State is the current state, embedded in a wrapper that ensures that
	// it can be safely accessed and modified concurrently.
	State *states.SyncState

	// Changes is the set of proposed changes, embedded in a wrapper that
	// ensures they can be safely accessed and modified concurrently.
	Changes *plans.ChangesSync
}

Evaluator provides the necessary contextual data for evaluating expressions for a particular walk operation.

func (*Evaluator) Scope added in v0.12.0

func (e *Evaluator) Scope(data lang.Data, self addrs.Referenceable) *lang.Scope

Scope creates an evaluation scope for the given module path and optional resource.

If the "self" argument is nil then the "self" object is not available in evaluated expressions. Otherwise, it behaves as an alias for the given address.

type ForcedCBDTransformer added in v0.12.0

type ForcedCBDTransformer struct {
}

ForcedCBDTransformer detects when a particular CBD-able graph node has dependencies with another that has create_before_destroy set that require it to be forced on, and forces it on.

This must be used in the plan graph builder to ensure that create_before_destroy settings are properly propagated before constructing the planned changes. This requires that the plannable resource nodes implement GraphNodeDestroyerCBD.

func (*ForcedCBDTransformer) Transform added in v0.12.0

func (t *ForcedCBDTransformer) Transform(g *Graph) error

type Graph

type Graph struct {
	// Graph is the actual DAG. This is embedded so you can call the DAG
	// methods directly.
	dag.AcyclicGraph

	// Path is the path in the module tree that this Graph represents.
	Path addrs.ModuleInstance
}

Graph represents the graph that Terraform uses to represent resources and their dependencies.

func (*Graph) DirectedGraph added in v0.8.0

func (g *Graph) DirectedGraph() dag.Grapher

func (*Graph) Walk added in v0.4.0

func (g *Graph) Walk(walker GraphWalker) tfdiags.Diagnostics

Walk walks the graph with the given walker for callbacks. The graph will be walked with full parallelism, so the walker should expect to be called in concurrently.

type GraphBuilder added in v0.4.0

type GraphBuilder interface {
	// Build builds the graph for the given module path. It is up to
	// the interface implementation whether this build should expand
	// the graph or not.
	Build(addrs.ModuleInstance) (*Graph, tfdiags.Diagnostics)
}

GraphBuilder is an interface that can be implemented and used with Terraform to build the graph that Terraform walks.

func ValidateGraphBuilder added in v0.9.0

func ValidateGraphBuilder(p *PlanGraphBuilder) GraphBuilder

ValidateGraphBuilder creates the graph for the validate operation.

ValidateGraphBuilder is based on the PlanGraphBuilder. We do this so that we only have to validate what we'd normally plan anyways. The PlanGraphBuilder given will be modified so it shouldn't be used for anything else after calling this function.

type GraphNodeAttachDependencies added in v0.12.14

type GraphNodeAttachDependencies interface {
	GraphNodeConfigResource
	AttachDependencies([]addrs.ConfigResource)
}

type GraphNodeAttachProvider added in v0.7.8

type GraphNodeAttachProvider interface {
	// ProviderName with no module prefix. Example: "aws".
	ProviderAddr() addrs.AbsProviderConfig

	// Sets the configuration
	AttachProvider(*configs.Provider)
}

GraphNodeAttachProvider is an interface that must be implemented by nodes that want provider configurations attached.

type GraphNodeAttachProviderConfigSchema added in v0.12.0

type GraphNodeAttachProviderConfigSchema interface {
	GraphNodeProvider

	AttachProviderConfigSchema(*configschema.Block)
}

GraphNodeAttachProviderConfigSchema is an interface implemented by node types that need a provider configuration schema attached.

type GraphNodeAttachProviderMetaConfigs added in v0.13.0

type GraphNodeAttachProviderMetaConfigs interface {
	GraphNodeConfigResource

	// Sets the configuration
	AttachProviderMetaConfigs(map[addrs.Provider]*configs.ProviderMeta)
}

GraphNodeAttachProviderMetaConfigs is an interface that must be implemented by nodes that want provider meta configurations attached.

type GraphNodeAttachProvisionerSchema added in v0.12.0

type GraphNodeAttachProvisionerSchema interface {
	ProvisionedBy() []string

	// SetProvisionerSchema is called during transform for each provisioner
	// type returned from ProvisionedBy, providing the configuration schema
	// for each provisioner in turn. The implementer should save these for
	// later use in evaluating provisioner configuration blocks.
	AttachProvisionerSchema(name string, schema *configschema.Block)
}

GraphNodeAttachProvisionerSchema is an interface implemented by node types that need one or more provisioner schemas attached.

type GraphNodeAttachResourceConfig added in v0.7.8

type GraphNodeAttachResourceConfig interface {
	GraphNodeConfigResource

	// Sets the configuration
	AttachResourceConfig(*configs.Resource)
}

GraphNodeAttachResourceConfig is an interface that must be implemented by nodes that want resource configurations attached.

type GraphNodeAttachResourceSchema added in v0.12.0

type GraphNodeAttachResourceSchema interface {
	GraphNodeConfigResource
	GraphNodeProviderConsumer

	AttachResourceSchema(schema *configschema.Block, version uint64)
}

GraphNodeAttachResourceSchema is an interface implemented by node types that need a resource schema attached.

type GraphNodeAttachResourceState added in v0.7.8

type GraphNodeAttachResourceState interface {
	GraphNodeResourceInstance

	// Sets the state
	AttachResourceState(*states.Resource)
}

GraphNodeAttachResourceState is an interface that can be implemented to request that a ResourceState is attached to the node.

Due to a historical naming inconsistency, the type ResourceState actually represents the state for a particular _instance_, while InstanceState represents the values for that instance during a particular phase (e.g. primary vs. deposed). Consequently, GraphNodeAttachResourceState is supported only for nodes that represent resource instances, even though the name might suggest it is for containing resources.

type GraphNodeCloseProvider added in v0.6.0

type GraphNodeCloseProvider interface {
	GraphNodeModulePath
	CloseProviderAddr() addrs.AbsProviderConfig
}

GraphNodeCloseProvider is an interface that nodes that can be a close provider must implement. The CloseProviderName returned is the name of the provider they satisfy.

type GraphNodeConfigResource added in v0.4.0

type GraphNodeConfigResource interface {
	ResourceAddr() addrs.ConfigResource
}

GraphNodeConfigResource is implemented by any nodes that represent a resource. The type of operation cannot be assumed, only that this node represents the given resource.

type GraphNodeCreator added in v0.7.8

type GraphNodeCreator interface {
	// CreateAddr is the address of the resource being created or updated
	CreateAddr() *addrs.AbsResourceInstance
}

GraphNodeCreator must be implemented by nodes that create OR update resources.

type GraphNodeDeposedResourceInstanceObject added in v0.12.0

type GraphNodeDeposedResourceInstanceObject interface {
	DeposedInstanceObjectKey() states.DeposedKey
}

type GraphNodeDeposer added in v0.12.0

type GraphNodeDeposer interface {
	// SetPreallocatedDeposedKey will be called during graph construction
	// if a particular node must use a pre-allocated deposed key if/when it
	// "deposes" the current object of its associated resource instance.
	SetPreallocatedDeposedKey(key states.DeposedKey)
}

GraphNodeDeposer is an optional interface implemented by graph nodes that might create a single new deposed object for a specific associated resource instance, allowing a caller to optionally pre-allocate a DeposedKey for it.

type GraphNodeDestroyer added in v0.7.8

type GraphNodeDestroyer interface {
	dag.Vertex

	// DestroyAddr is the address of the resource that is being
	// destroyed by this node. If this returns nil, then this node
	// is not destroying anything.
	DestroyAddr() *addrs.AbsResourceInstance
}

GraphNodeDestroyer must be implemented by nodes that destroy resources.

type GraphNodeDestroyerCBD added in v0.7.8

type GraphNodeDestroyerCBD interface {
	// CreateBeforeDestroy returns true if this node represents a node
	// that is doing a CBD.
	CreateBeforeDestroy() bool

	// ModifyCreateBeforeDestroy is called when the CBD state of a node
	// is changed dynamically. This can return an error if this isn't
	// allowed.
	ModifyCreateBeforeDestroy(bool) error
}

GraphNodeDestroyerCBD must be implemented by nodes that might be create-before-destroy destroyers, or might plan a create-before-destroy action.

type GraphNodeDynamicExpandable added in v0.4.0

type GraphNodeDynamicExpandable interface {
	DynamicExpand(EvalContext) (*Graph, error)
}

GraphNodeDynamicExpandable is an interface that nodes can implement to signal that they can be expanded at eval-time (hence dynamic). These nodes are given the eval context and are expected to return a new subgraph.

type GraphNodeExecutable added in v0.14.0

type GraphNodeExecutable interface {
	Execute(EvalContext, walkOperation) tfdiags.Diagnostics
}

GraphNodeExecutable is the interface that graph nodes must implement to enable execution.

type GraphNodeModuleInstance added in v0.13.0

type GraphNodeModuleInstance interface {
	Path() addrs.ModuleInstance
}

GraphNodeModuleInstance says that a node is part of a graph with a different path, and the context should be adjusted accordingly.

type GraphNodeModulePath added in v0.13.0

type GraphNodeModulePath interface {
	ModulePath() addrs.Module
}

GraphNodeModulePath is implemented by all referenceable nodes, to indicate their configuration path in unexpanded modules.

type GraphNodeProvider added in v0.4.0

type GraphNodeProvider interface {
	GraphNodeModulePath
	ProviderAddr() addrs.AbsProviderConfig
	Name() string
}

GraphNodeProvider is an interface that nodes that can be a provider must implement.

ProviderAddr returns the address of the provider configuration this satisfies, which is relative to the path returned by method Path().

Name returns the full name of the provider in the config.

type GraphNodeProviderConsumer added in v0.4.0

type GraphNodeProviderConsumer interface {
	GraphNodeModulePath
	// ProvidedBy returns the address of the provider configuration the node
	// refers to, if available. The following value types may be returned:
	//
	//   nil + exact true: the node does not require a provider
	// * addrs.LocalProviderConfig: the provider was set in the resource config
	// * addrs.AbsProviderConfig + exact true: the provider configuration was
	//   taken from the instance state.
	// * addrs.AbsProviderConfig + exact false: no config or state; the returned
	//   value is a default provider configuration address for the resource's
	//   Provider
	ProvidedBy() (addr addrs.ProviderConfig, exact bool)

	// Provider() returns the Provider FQN for the node.
	Provider() (provider addrs.Provider)

	// Set the resolved provider address for this resource.
	SetProvider(addrs.AbsProviderConfig)
}

GraphNodeProviderConsumer is an interface that nodes that require a provider must implement. ProvidedBy must return the address of the provider to use, which will be resolved to a configuration either in the same module or in an ancestor module, with the resulting absolute address passed to SetProvider.

type GraphNodeProvisionerConsumer added in v0.4.0

type GraphNodeProvisionerConsumer interface {
	ProvisionedBy() []string
}

GraphNodeProvisionerConsumer is an interface that nodes that require a provisioner must implement. ProvisionedBy must return the names of the provisioners to use.

type GraphNodeReferenceOutside added in v0.12.0

type GraphNodeReferenceOutside interface {
	// ReferenceOutside returns a path in which any references from this node
	// are resolved.
	ReferenceOutside() (selfPath, referencePath addrs.Module)
}

GraphNodeReferenceOutside is an interface that can optionally be implemented. A node that implements it can specify that its own referenceable addresses and/or the addresses it references are in a different module than the node itself.

Any referenceable addresses returned by ReferenceableAddrs are interpreted relative to the returned selfPath.

Any references returned by References are interpreted relative to the returned referencePath.

It is valid but not required for either of these paths to match what is returned by method Path, though if both match the main Path then there is no reason to implement this method.

The primary use-case for this is the nodes representing module input variables, since their expressions are resolved in terms of their calling module, but they are still referenced from their own module.

type GraphNodeReferenceable added in v0.7.8

type GraphNodeReferenceable interface {
	GraphNodeModulePath

	// ReferenceableAddrs returns a list of addresses through which this can be
	// referenced.
	ReferenceableAddrs() []addrs.Referenceable
}

GraphNodeReferenceable must be implemented by any node that represents a Terraform thing that can be referenced (resource, module, etc.).

Even if the thing has no name, this should return an empty list. By implementing this and returning a non-nil result, you say that this CAN be referenced and other methods of referencing may still be possible (such as by path!)

type GraphNodeReferencer added in v0.7.8

type GraphNodeReferencer interface {
	GraphNodeModulePath

	// References returns a list of references made by this node, which
	// include both a referenced address and source location information for
	// the reference.
	References() []*addrs.Reference
}

GraphNodeReferencer must be implemented by nodes that reference other Terraform items and therefore depend on them.

type GraphNodeResourceInstance added in v0.12.0

type GraphNodeResourceInstance interface {
	ResourceInstanceAddr() addrs.AbsResourceInstance

	// StateDependencies returns any inter-resource dependencies that are
	// stored in the state.
	StateDependencies() []addrs.ConfigResource
}

GraphNodeResourceInstance is implemented by any nodes that represent a resource instance. A single resource may have multiple instances if, for example, the "count" or "for_each" argument is used for it in configuration.

type GraphNodeTargetable added in v0.4.0

type GraphNodeTargetable interface {
	SetTargets([]addrs.Targetable)
}

GraphNodeTargetable is an interface for graph nodes to implement when they need to be told about incoming targets. This is useful for nodes that need to respect targets as they dynamically expand. Note that the list of targets provided will contain every target provided, and each implementing graph node must filter this list to targets considered relevant.

type GraphTransformer added in v0.4.0

type GraphTransformer interface {
	Transform(*Graph) error
}

GraphTransformer is the interface that transformers implement. This interface is only for transforms that need entire graph visibility.

func GraphTransformMulti added in v0.7.8

func GraphTransformMulti(ts ...GraphTransformer) GraphTransformer

GraphTransformMulti combines multiple graph transformers into a single GraphTransformer that runs all the individual graph transformers.

func TransformProviders added in v0.11.0

func TransformProviders(providers []string, concrete ConcreteProviderNodeFunc, config *configs.Config) GraphTransformer

type GraphType added in v0.8.0

type GraphType byte

GraphType is an enum of the type of graph to create with a Context. The values of the constants may change so they shouldn't be depended on; always use the constant name.

const (
	GraphTypeInvalid GraphType = iota
	GraphTypePlan
	GraphTypePlanDestroy
	GraphTypePlanRefreshOnly
	GraphTypeApply
	GraphTypeValidate
	GraphTypeEval // only visits in-memory elements such as variables, locals, and outputs.
)

func (GraphType) String added in v0.8.0

func (i GraphType) String() string

type GraphVertexTransformer added in v0.4.0

type GraphVertexTransformer interface {
	Transform(dag.Vertex) (dag.Vertex, error)
}

GraphVertexTransformer is an interface that transforms a single Vertex within with graph. This is a specialization of GraphTransformer that makes it easy to do vertex replacement.

The GraphTransformer that runs through the GraphVertexTransformers is VertexTransformer.

type GraphWalker added in v0.4.0

type GraphWalker interface {
	EvalContext() EvalContext
	EnterPath(addrs.ModuleInstance) EvalContext
	ExitPath(addrs.ModuleInstance)
	Execute(EvalContext, GraphNodeExecutable) tfdiags.Diagnostics
}

GraphWalker is an interface that can be implemented that when used with Graph.Walk will invoke the given callbacks under certain events.

type Hook

type Hook interface {
	// PreApply and PostApply are called before and after an action for a
	// single instance is applied. The error argument in PostApply is the
	// error, if any, that was returned from the provider Apply call itself.
	PreApply(addr addrs.AbsResourceInstance, gen states.Generation, action plans.Action, priorState, plannedNewState cty.Value) (HookAction, error)
	PostApply(addr addrs.AbsResourceInstance, gen states.Generation, newState cty.Value, err error) (HookAction, error)

	// PreDiff and PostDiff are called before and after a provider is given
	// the opportunity to customize the proposed new state to produce the
	// planned new state.
	PreDiff(addr addrs.AbsResourceInstance, gen states.Generation, priorState, proposedNewState cty.Value) (HookAction, error)
	PostDiff(addr addrs.AbsResourceInstance, gen states.Generation, action plans.Action, priorState, plannedNewState cty.Value) (HookAction, error)

	// The provisioning hooks signal both the overall start end end of
	// provisioning for a particular instance and of each of the individual
	// configured provisioners for each instance. The sequence of these
	// for a given instance might look something like this:
	//
	//          PreProvisionInstance(aws_instance.foo[1], ...)
	//      PreProvisionInstanceStep(aws_instance.foo[1], "file")
	//     PostProvisionInstanceStep(aws_instance.foo[1], "file", nil)
	//      PreProvisionInstanceStep(aws_instance.foo[1], "remote-exec")
	//               ProvisionOutput(aws_instance.foo[1], "remote-exec", "Installing foo...")
	//               ProvisionOutput(aws_instance.foo[1], "remote-exec", "Configuring bar...")
	//     PostProvisionInstanceStep(aws_instance.foo[1], "remote-exec", nil)
	//         PostProvisionInstance(aws_instance.foo[1], ...)
	//
	// ProvisionOutput is called with output sent back by the provisioners.
	// This will be called multiple times as output comes in, with each call
	// representing one line of output. It cannot control whether the
	// provisioner continues running.
	PreProvisionInstance(addr addrs.AbsResourceInstance, state cty.Value) (HookAction, error)
	PostProvisionInstance(addr addrs.AbsResourceInstance, state cty.Value) (HookAction, error)
	PreProvisionInstanceStep(addr addrs.AbsResourceInstance, typeName string) (HookAction, error)
	PostProvisionInstanceStep(addr addrs.AbsResourceInstance, typeName string, err error) (HookAction, error)
	ProvisionOutput(addr addrs.AbsResourceInstance, typeName string, line string)

	// PreRefresh and PostRefresh are called before and after a single
	// resource state is refreshed, respectively.
	PreRefresh(addr addrs.AbsResourceInstance, gen states.Generation, priorState cty.Value) (HookAction, error)
	PostRefresh(addr addrs.AbsResourceInstance, gen states.Generation, priorState cty.Value, newState cty.Value) (HookAction, error)

	// PreImportState and PostImportState are called before and after
	// (respectively) each state import operation for a given resource address.
	PreImportState(addr addrs.AbsResourceInstance, importID string) (HookAction, error)
	PostImportState(addr addrs.AbsResourceInstance, imported []providers.ImportedResource) (HookAction, error)

	// PostStateUpdate is called each time the state is updated. It receives
	// a deep copy of the state, which it may therefore access freely without
	// any need for locks to protect from concurrent writes from the caller.
	PostStateUpdate(new *states.State) (HookAction, error)
}

Hook is the interface that must be implemented to hook into various parts of Terraform, allowing you to inspect or change behavior at runtime.

There are MANY hook points into Terraform. If you only want to implement some hook points, but not all (which is the likely case), then embed the NilHook into your struct, which implements all of the interface but does nothing. Then, override only the functions you want to implement.

type HookAction

type HookAction byte

HookAction is an enum of actions that can be taken as a result of a hook callback. This allows you to modify the behavior of Terraform at runtime.

const (
	// HookActionContinue continues with processing as usual.
	HookActionContinue HookAction = iota

	// HookActionHalt halts immediately: no more hooks are processed
	// and the action that Terraform was about to take is cancelled.
	HookActionHalt
)

type ImportGraphBuilder added in v0.7.0

type ImportGraphBuilder struct {
	// ImportTargets are the list of resources to import.
	ImportTargets []*ImportTarget

	// Module is a configuration to build the graph from. See ImportOpts.Config.
	Config *configs.Config

	// Components is the factory for our available plugin components.
	Components contextComponentFactory

	// Schemas is the repository of schemas we will draw from to analyse
	// the configuration.
	Schemas *Schemas
}

ImportGraphBuilder implements GraphBuilder and is responsible for building a graph for importing resources into Terraform. This is a much, much simpler graph than a normal configuration graph.

func (*ImportGraphBuilder) Build added in v0.7.0

Build builds the graph according to the steps returned by Steps.

func (*ImportGraphBuilder) Steps added in v0.7.0

func (b *ImportGraphBuilder) Steps() []GraphTransformer

Steps returns the ordered list of GraphTransformers that must be executed to build a complete graph.

type ImportOpts added in v0.7.0

type ImportOpts struct {
	// Targets are the targets to import
	Targets []*ImportTarget
}

ImportOpts are used as the configuration for Import.

type ImportStateTransformer added in v0.7.0

type ImportStateTransformer struct {
	Targets []*ImportTarget
	Config  *configs.Config
}

ImportStateTransformer is a GraphTransformer that adds nodes to the graph to represent the imports we want to do for resources.

func (*ImportStateTransformer) Transform added in v0.7.0

func (t *ImportStateTransformer) Transform(g *Graph) error

type ImportTarget added in v0.7.0

type ImportTarget struct {
	// Addr is the address for the resource instance that the new object should
	// be imported into.
	Addr addrs.AbsResourceInstance

	// ID is the ID of the resource to import. This is resource-specific.
	ID string

	// ProviderAddr is the address of the provider that should handle the import.
	ProviderAddr addrs.AbsProviderConfig
}

ImportTarget is a single resource to import.

type InputMode added in v0.3.0

type InputMode byte

InputMode defines what sort of input will be asked for when Input is called on Context.

const (
	// InputModeProvider asks for provider variables
	InputModeProvider InputMode = 1 << iota

	// InputModeStd is the standard operating mode and asks for both variables
	// and providers.
	InputModeStd = InputModeProvider
)

type InputOpts added in v0.3.0

type InputOpts struct {
	// Id is a unique ID for the question being asked that might be
	// used for logging or to look up a prior answered question.
	Id string

	// Query is a human-friendly question for inputting this value.
	Query string

	// Description is a description about what this option is. Be wary
	// that this will probably be in a terminal so split lines as you see
	// necessary.
	Description string

	// Default will be the value returned if no data is entered.
	Default string

	// Secret should be true if we are asking for sensitive input.
	// If attached to a TTY, Terraform will disable echo.
	Secret bool
}

InputOpts are options for asking for input.

type InputValue added in v0.12.0

type InputValue struct {
	Value      cty.Value
	SourceType ValueSourceType

	// SourceRange provides source location information for values whose
	// SourceType is either ValueFromConfig or ValueFromFile. It is not
	// populated for other source types, and so should not be used.
	SourceRange tfdiags.SourceRange
}

InputValue represents a value for a variable in the root module, provided as part of the definition of an operation.

func (*InputValue) GoString added in v0.12.0

func (v *InputValue) GoString() string

type InputValues added in v0.12.0

type InputValues map[string]*InputValue

InputValues is a map of InputValue instances.

func DefaultVariableValues added in v0.12.0

func DefaultVariableValues(configs map[string]*configs.Variable) InputValues

DefaultVariableValues returns an InputValues map representing the default values specified for variables in the given configuration map.

func InputValuesFromCaller added in v0.12.0

func InputValuesFromCaller(vals map[string]cty.Value) InputValues

InputValuesFromCaller turns the given map of naked values into an InputValues that attributes each value to "a caller", using the source type ValueFromCaller. This is primarily useful for testing purposes.

This should not be used as a general way to convert map[string]cty.Value into InputValues, since in most real cases we want to set a suitable other SourceType and possibly SourceRange value.

func (InputValues) HasValues added in v0.12.0

func (vv InputValues) HasValues(vals map[string]cty.Value) bool

HasValues returns true if the reciever has the same values as in the given map, disregarding the source types and source ranges.

Values are compared using the cty "RawEquals" method, which means that unknown values can be considered equal to one another if they are of the same type.

func (InputValues) Identical added in v0.12.0

func (vv InputValues) Identical(other InputValues) bool

Identical returns true if the given InputValues has the same values, source types, and source ranges as the receiver.

Values are compared using the cty "RawEquals" method, which means that unknown values can be considered equal to one another if they are of the same type.

This method is primarily for testing. For most practical purposes, it's better to use SameValues or HasValues.

func (InputValues) JustValues added in v0.12.0

func (vv InputValues) JustValues() map[string]cty.Value

JustValues returns a map that just includes the values, discarding the source information.

func (InputValues) Override added in v0.12.0

func (vv InputValues) Override(others ...InputValues) InputValues

Override merges the given value maps with the receiver, overriding any conflicting keys so that the latest definition wins.

func (InputValues) SameValues added in v0.12.0

func (vv InputValues) SameValues(other InputValues) bool

SameValues returns true if the given InputValues has the same values as the receiever, disregarding the source types and source ranges.

Values are compared using the cty "RawEquals" method, which means that unknown values can be considered equal to one another if they are of the same type.

type InstanceKeyEvalData added in v0.12.0

type InstanceKeyEvalData = instances.RepetitionData

InstanceKeyEvalData is the old name for instances.RepetitionData, aliased here for compatibility. In new code, use instances.RepetitionData instead.

func EvalDataForInstanceKey added in v0.12.0

func EvalDataForInstanceKey(key addrs.InstanceKey, forEachMap map[string]cty.Value) InstanceKeyEvalData

EvalDataForInstanceKey constructs a suitable InstanceKeyEvalData for evaluating in a context that has the given instance key.

The forEachMap argument can be nil when preparing for evaluation in a context where each.value is prohibited, such as a destroy-time provisioner. In that case, the returned EachValue will always be cty.NilVal.

type LocalTransformer added in v0.10.3

type LocalTransformer struct {
	Config *configs.Config
}

LocalTransformer is a GraphTransformer that adds all the local values from the configuration to the graph.

func (*LocalTransformer) Transform added in v0.10.3

func (t *LocalTransformer) Transform(g *Graph) error

type MissingProviderTransformer added in v0.4.0

type MissingProviderTransformer struct {
	// Providers is the list of providers we support.
	Providers []string

	// MissingProviderTransformer needs the config to rule out _implied_ default providers
	Config *configs.Config

	// Concrete, if set, overrides how the providers are made.
	Concrete ConcreteProviderNodeFunc
}

MissingProviderTransformer is a GraphTransformer that adds to the graph a node for each default provider configuration that is referenced by another node but not already present in the graph.

These "default" nodes are always added to the root module, regardless of where they are requested. This is important because our inheritance resolution behavior in ProviderTransformer will then treat these as a last-ditch fallback after walking up the tree, rather than preferring them as it would if they were placed in the same module as the requester.

This transformer may create extra nodes that are not needed in practice, due to overriding provider configurations in child modules. PruneProviderTransformer can then remove these once ProviderTransformer has resolved all of the inheritence, etc.

func (*MissingProviderTransformer) Transform added in v0.4.0

func (t *MissingProviderTransformer) Transform(g *Graph) error

type MockEvalContext added in v0.4.0

type MockEvalContext struct {
	StoppedCalled bool
	StoppedValue  <-chan struct{}

	HookCalled bool
	HookHook   Hook
	HookError  error

	InputCalled bool
	InputInput  UIInput

	InitProviderCalled   bool
	InitProviderType     string
	InitProviderAddr     addrs.AbsProviderConfig
	InitProviderProvider providers.Interface
	InitProviderError    error

	ProviderCalled   bool
	ProviderAddr     addrs.AbsProviderConfig
	ProviderProvider providers.Interface

	ProviderSchemaCalled bool
	ProviderSchemaAddr   addrs.AbsProviderConfig
	ProviderSchemaSchema *ProviderSchema

	CloseProviderCalled   bool
	CloseProviderAddr     addrs.AbsProviderConfig
	CloseProviderProvider providers.Interface

	ProviderInputCalled bool
	ProviderInputAddr   addrs.AbsProviderConfig
	ProviderInputValues map[string]cty.Value

	SetProviderInputCalled bool
	SetProviderInputAddr   addrs.AbsProviderConfig
	SetProviderInputValues map[string]cty.Value

	ConfigureProviderFn func(
		addr addrs.AbsProviderConfig,
		cfg cty.Value) tfdiags.Diagnostics // overrides the other values below, if set
	ConfigureProviderCalled bool
	ConfigureProviderAddr   addrs.AbsProviderConfig
	ConfigureProviderConfig cty.Value
	ConfigureProviderDiags  tfdiags.Diagnostics

	ProvisionerCalled      bool
	ProvisionerName        string
	ProvisionerProvisioner provisioners.Interface

	ProvisionerSchemaCalled bool
	ProvisionerSchemaName   string
	ProvisionerSchemaSchema *configschema.Block

	CloseProvisionersCalled bool

	EvaluateBlockCalled     bool
	EvaluateBlockBody       hcl.Body
	EvaluateBlockSchema     *configschema.Block
	EvaluateBlockSelf       addrs.Referenceable
	EvaluateBlockKeyData    InstanceKeyEvalData
	EvaluateBlockResultFunc func(
		body hcl.Body,
		schema *configschema.Block,
		self addrs.Referenceable,
		keyData InstanceKeyEvalData,
	) (cty.Value, hcl.Body, tfdiags.Diagnostics) // overrides the other values below, if set
	EvaluateBlockResult       cty.Value
	EvaluateBlockExpandedBody hcl.Body
	EvaluateBlockDiags        tfdiags.Diagnostics

	EvaluateExprCalled     bool
	EvaluateExprExpr       hcl.Expression
	EvaluateExprWantType   cty.Type
	EvaluateExprSelf       addrs.Referenceable
	EvaluateExprResultFunc func(
		expr hcl.Expression,
		wantType cty.Type,
		self addrs.Referenceable,
	) (cty.Value, tfdiags.Diagnostics) // overrides the other values below, if set
	EvaluateExprResult cty.Value
	EvaluateExprDiags  tfdiags.Diagnostics

	EvaluationScopeCalled  bool
	EvaluationScopeSelf    addrs.Referenceable
	EvaluationScopeKeyData InstanceKeyEvalData
	EvaluationScopeScope   *lang.Scope

	PathCalled bool
	PathPath   addrs.ModuleInstance

	SetModuleCallArgumentsCalled bool
	SetModuleCallArgumentsModule addrs.ModuleCallInstance
	SetModuleCallArgumentsValues map[string]cty.Value

	GetVariableValueCalled bool
	GetVariableValueAddr   addrs.AbsInputVariableInstance
	GetVariableValueValue  cty.Value

	ChangesCalled  bool
	ChangesChanges *plans.ChangesSync

	StateCalled bool
	StateState  *states.SyncState

	RefreshStateCalled bool
	RefreshStateState  *states.SyncState

	PrevRunStateCalled bool
	PrevRunStateState  *states.SyncState

	InstanceExpanderCalled   bool
	InstanceExpanderExpander *instances.Expander
}

MockEvalContext is a mock version of EvalContext that can be used for tests.

func (*MockEvalContext) Changes added in v0.12.0

func (c *MockEvalContext) Changes() *plans.ChangesSync

func (*MockEvalContext) CloseProvider added in v0.6.0

func (c *MockEvalContext) CloseProvider(addr addrs.AbsProviderConfig) error

func (*MockEvalContext) CloseProvisioners added in v0.15.0

func (c *MockEvalContext) CloseProvisioners() error

func (*MockEvalContext) ConfigureProvider added in v0.4.0

func (c *MockEvalContext) ConfigureProvider(addr addrs.AbsProviderConfig, cfg cty.Value) tfdiags.Diagnostics

func (*MockEvalContext) EvaluateBlock added in v0.12.0

func (c *MockEvalContext) EvaluateBlock(body hcl.Body, schema *configschema.Block, self addrs.Referenceable, keyData InstanceKeyEvalData) (cty.Value, hcl.Body, tfdiags.Diagnostics)

func (*MockEvalContext) EvaluateExpr added in v0.12.0

func (c *MockEvalContext) EvaluateExpr(expr hcl.Expression, wantType cty.Type, self addrs.Referenceable) (cty.Value, tfdiags.Diagnostics)

func (*MockEvalContext) EvaluationScope added in v0.12.0

func (c *MockEvalContext) EvaluationScope(self addrs.Referenceable, keyData InstanceKeyEvalData) *lang.Scope

func (*MockEvalContext) GetVariableValue added in v0.12.20

func (c *MockEvalContext) GetVariableValue(addr addrs.AbsInputVariableInstance) cty.Value

func (*MockEvalContext) Hook added in v0.4.0

func (c *MockEvalContext) Hook(fn func(Hook) (HookAction, error)) error

func (*MockEvalContext) InitProvider added in v0.4.0

func (*MockEvalContext) Input added in v0.4.0

func (c *MockEvalContext) Input() UIInput

func (*MockEvalContext) InstanceExpander added in v0.13.0

func (c *MockEvalContext) InstanceExpander() *instances.Expander

func (*MockEvalContext) Path added in v0.4.0

func (*MockEvalContext) PrevRunState added in v0.15.3

func (c *MockEvalContext) PrevRunState() *states.SyncState

func (*MockEvalContext) Provider added in v0.4.0

func (*MockEvalContext) ProviderInput added in v0.4.0

func (c *MockEvalContext) ProviderInput(addr addrs.AbsProviderConfig) map[string]cty.Value

func (*MockEvalContext) ProviderSchema added in v0.12.0

func (c *MockEvalContext) ProviderSchema(addr addrs.AbsProviderConfig) *ProviderSchema

func (*MockEvalContext) Provisioner added in v0.4.0

func (c *MockEvalContext) Provisioner(n string) (provisioners.Interface, error)

func (*MockEvalContext) ProvisionerSchema added in v0.12.0

func (c *MockEvalContext) ProvisionerSchema(n string) *configschema.Block

func (*MockEvalContext) RefreshState added in v0.14.0

func (c *MockEvalContext) RefreshState() *states.SyncState

func (*MockEvalContext) SetModuleCallArguments added in v0.12.0

func (c *MockEvalContext) SetModuleCallArguments(n addrs.ModuleCallInstance, values map[string]cty.Value)

func (*MockEvalContext) SetProviderInput added in v0.4.0

func (c *MockEvalContext) SetProviderInput(addr addrs.AbsProviderConfig, vals map[string]cty.Value)

func (*MockEvalContext) State added in v0.4.0

func (c *MockEvalContext) State() *states.SyncState

func (*MockEvalContext) Stopped added in v0.9.0

func (c *MockEvalContext) Stopped() <-chan struct{}

func (*MockEvalContext) WithPath added in v0.13.0

func (c *MockEvalContext) WithPath(path addrs.ModuleInstance) EvalContext

type MockHook

type MockHook struct {
	sync.Mutex

	PreApplyCalled       bool
	PreApplyAddr         addrs.AbsResourceInstance
	PreApplyGen          states.Generation
	PreApplyAction       plans.Action
	PreApplyPriorState   cty.Value
	PreApplyPlannedState cty.Value
	PreApplyReturn       HookAction
	PreApplyError        error

	PostApplyCalled      bool
	PostApplyAddr        addrs.AbsResourceInstance
	PostApplyGen         states.Generation
	PostApplyNewState    cty.Value
	PostApplyError       error
	PostApplyReturn      HookAction
	PostApplyReturnError error
	PostApplyFn          func(addrs.AbsResourceInstance, states.Generation, cty.Value, error) (HookAction, error)

	PreDiffCalled        bool
	PreDiffAddr          addrs.AbsResourceInstance
	PreDiffGen           states.Generation
	PreDiffPriorState    cty.Value
	PreDiffProposedState cty.Value
	PreDiffReturn        HookAction
	PreDiffError         error

	PostDiffCalled       bool
	PostDiffAddr         addrs.AbsResourceInstance
	PostDiffGen          states.Generation
	PostDiffAction       plans.Action
	PostDiffPriorState   cty.Value
	PostDiffPlannedState cty.Value
	PostDiffReturn       HookAction
	PostDiffError        error

	PreProvisionInstanceCalled bool
	PreProvisionInstanceAddr   addrs.AbsResourceInstance
	PreProvisionInstanceState  cty.Value
	PreProvisionInstanceReturn HookAction
	PreProvisionInstanceError  error

	PostProvisionInstanceCalled bool
	PostProvisionInstanceAddr   addrs.AbsResourceInstance
	PostProvisionInstanceState  cty.Value
	PostProvisionInstanceReturn HookAction
	PostProvisionInstanceError  error

	PreProvisionInstanceStepCalled          bool
	PreProvisionInstanceStepAddr            addrs.AbsResourceInstance
	PreProvisionInstanceStepProvisionerType string
	PreProvisionInstanceStepReturn          HookAction
	PreProvisionInstanceStepError           error

	PostProvisionInstanceStepCalled          bool
	PostProvisionInstanceStepAddr            addrs.AbsResourceInstance
	PostProvisionInstanceStepProvisionerType string
	PostProvisionInstanceStepErrorArg        error
	PostProvisionInstanceStepReturn          HookAction
	PostProvisionInstanceStepError           error

	ProvisionOutputCalled          bool
	ProvisionOutputAddr            addrs.AbsResourceInstance
	ProvisionOutputProvisionerType string
	ProvisionOutputMessage         string

	PreRefreshCalled     bool
	PreRefreshAddr       addrs.AbsResourceInstance
	PreRefreshGen        states.Generation
	PreRefreshPriorState cty.Value
	PreRefreshReturn     HookAction
	PreRefreshError      error

	PostRefreshCalled     bool
	PostRefreshAddr       addrs.AbsResourceInstance
	PostRefreshGen        states.Generation
	PostRefreshPriorState cty.Value
	PostRefreshNewState   cty.Value
	PostRefreshReturn     HookAction
	PostRefreshError      error

	PreImportStateCalled bool
	PreImportStateAddr   addrs.AbsResourceInstance
	PreImportStateID     string
	PreImportStateReturn HookAction
	PreImportStateError  error

	PostImportStateCalled    bool
	PostImportStateAddr      addrs.AbsResourceInstance
	PostImportStateNewStates []providers.ImportedResource
	PostImportStateReturn    HookAction
	PostImportStateError     error

	PostStateUpdateCalled bool
	PostStateUpdateState  *states.State
	PostStateUpdateReturn HookAction
	PostStateUpdateError  error
}

MockHook is an implementation of Hook that can be used for tests. It records all of its function calls.

func (*MockHook) PostApply

func (h *MockHook) PostApply(addr addrs.AbsResourceInstance, gen states.Generation, newState cty.Value, err error) (HookAction, error)

func (*MockHook) PostDiff

func (h *MockHook) PostDiff(addr addrs.AbsResourceInstance, gen states.Generation, action plans.Action, priorState, plannedNewState cty.Value) (HookAction, error)

func (*MockHook) PostImportState added in v0.7.0

func (h *MockHook) PostImportState(addr addrs.AbsResourceInstance, imported []providers.ImportedResource) (HookAction, error)

func (*MockHook) PostProvisionInstance added in v0.12.0

func (h *MockHook) PostProvisionInstance(addr addrs.AbsResourceInstance, state cty.Value) (HookAction, error)

func (*MockHook) PostProvisionInstanceStep added in v0.12.0

func (h *MockHook) PostProvisionInstanceStep(addr addrs.AbsResourceInstance, typeName string, err error) (HookAction, error)

func (*MockHook) PostRefresh

func (h *MockHook) PostRefresh(addr addrs.AbsResourceInstance, gen states.Generation, priorState cty.Value, newState cty.Value) (HookAction, error)

func (*MockHook) PostStateUpdate added in v0.4.0

func (h *MockHook) PostStateUpdate(new *states.State) (HookAction, error)

func (*MockHook) PreApply

func (h *MockHook) PreApply(addr addrs.AbsResourceInstance, gen states.Generation, action plans.Action, priorState, plannedNewState cty.Value) (HookAction, error)

func (*MockHook) PreDiff

func (h *MockHook) PreDiff(addr addrs.AbsResourceInstance, gen states.Generation, priorState, proposedNewState cty.Value) (HookAction, error)

func (*MockHook) PreImportState added in v0.7.0

func (h *MockHook) PreImportState(addr addrs.AbsResourceInstance, importID string) (HookAction, error)

func (*MockHook) PreProvisionInstance added in v0.12.0

func (h *MockHook) PreProvisionInstance(addr addrs.AbsResourceInstance, state cty.Value) (HookAction, error)

func (*MockHook) PreProvisionInstanceStep added in v0.12.0

func (h *MockHook) PreProvisionInstanceStep(addr addrs.AbsResourceInstance, typeName string) (HookAction, error)

func (*MockHook) PreRefresh

func (h *MockHook) PreRefresh(addr addrs.AbsResourceInstance, gen states.Generation, priorState cty.Value) (HookAction, error)

func (*MockHook) ProvisionOutput added in v0.3.0

func (h *MockHook) ProvisionOutput(addr addrs.AbsResourceInstance, typeName string, line string)

type MockProvider added in v0.12.0

type MockProvider struct {
	sync.Mutex

	// Anything you want, in case you need to store extra data with the mock.
	Meta interface{}

	GetProviderSchemaCalled   bool
	GetProviderSchemaResponse *providers.GetProviderSchemaResponse

	ValidateProviderConfigCalled   bool
	ValidateProviderConfigResponse *providers.ValidateProviderConfigResponse
	ValidateProviderConfigRequest  providers.ValidateProviderConfigRequest
	ValidateProviderConfigFn       func(providers.ValidateProviderConfigRequest) providers.ValidateProviderConfigResponse

	ValidateResourceConfigCalled   bool
	ValidateResourceConfigTypeName string
	ValidateResourceConfigResponse *providers.ValidateResourceConfigResponse
	ValidateResourceConfigRequest  providers.ValidateResourceConfigRequest
	ValidateResourceConfigFn       func(providers.ValidateResourceConfigRequest) providers.ValidateResourceConfigResponse

	ValidateDataResourceConfigCalled   bool
	ValidateDataResourceConfigTypeName string
	ValidateDataResourceConfigResponse *providers.ValidateDataResourceConfigResponse
	ValidateDataResourceConfigRequest  providers.ValidateDataResourceConfigRequest
	ValidateDataResourceConfigFn       func(providers.ValidateDataResourceConfigRequest) providers.ValidateDataResourceConfigResponse

	UpgradeResourceStateCalled   bool
	UpgradeResourceStateTypeName string
	UpgradeResourceStateResponse *providers.UpgradeResourceStateResponse
	UpgradeResourceStateRequest  providers.UpgradeResourceStateRequest
	UpgradeResourceStateFn       func(providers.UpgradeResourceStateRequest) providers.UpgradeResourceStateResponse

	ConfigureProviderCalled   bool
	ConfigureProviderResponse *providers.ConfigureProviderResponse
	ConfigureProviderRequest  providers.ConfigureProviderRequest
	ConfigureProviderFn       func(providers.ConfigureProviderRequest) providers.ConfigureProviderResponse

	StopCalled   bool
	StopFn       func() error
	StopResponse error

	ReadResourceCalled   bool
	ReadResourceResponse *providers.ReadResourceResponse
	ReadResourceRequest  providers.ReadResourceRequest
	ReadResourceFn       func(providers.ReadResourceRequest) providers.ReadResourceResponse

	PlanResourceChangeCalled   bool
	PlanResourceChangeResponse *providers.PlanResourceChangeResponse
	PlanResourceChangeRequest  providers.PlanResourceChangeRequest
	PlanResourceChangeFn       func(providers.PlanResourceChangeRequest) providers.PlanResourceChangeResponse

	ApplyResourceChangeCalled   bool
	ApplyResourceChangeResponse *providers.ApplyResourceChangeResponse
	ApplyResourceChangeRequest  providers.ApplyResourceChangeRequest
	ApplyResourceChangeFn       func(providers.ApplyResourceChangeRequest) providers.ApplyResourceChangeResponse

	ImportResourceStateCalled   bool
	ImportResourceStateResponse *providers.ImportResourceStateResponse
	ImportResourceStateRequest  providers.ImportResourceStateRequest
	ImportResourceStateFn       func(providers.ImportResourceStateRequest) providers.ImportResourceStateResponse

	ReadDataSourceCalled   bool
	ReadDataSourceResponse *providers.ReadDataSourceResponse
	ReadDataSourceRequest  providers.ReadDataSourceRequest
	ReadDataSourceFn       func(providers.ReadDataSourceRequest) providers.ReadDataSourceResponse

	CloseCalled bool
	CloseError  error
}

MockProvider implements providers.Interface but mocks out all the calls for testing purposes.

func (*MockProvider) ApplyResourceChange added in v0.12.0

func (*MockProvider) Close added in v0.12.0

func (p *MockProvider) Close() error

func (*MockProvider) ConfigureProvider added in v0.15.0

func (*MockProvider) GetProviderSchema added in v0.15.0

func (p *MockProvider) GetProviderSchema() providers.GetProviderSchemaResponse

func (*MockProvider) ImportResourceState added in v0.12.0

func (*MockProvider) PlanResourceChange added in v0.12.0

func (*MockProvider) ProviderSchema added in v0.15.0

func (p *MockProvider) ProviderSchema() *ProviderSchema

ProviderSchema is a helper to convert from the internal GetProviderSchemaResponse to a ProviderSchema.

func (*MockProvider) ReadDataSource added in v0.12.0

func (*MockProvider) ReadResource added in v0.12.0

func (*MockProvider) Stop added in v0.12.0

func (p *MockProvider) Stop() error

func (*MockProvider) UpgradeResourceState added in v0.12.0

func (*MockProvider) ValidateDataResourceConfig added in v0.15.0

func (*MockProvider) ValidateProviderConfig added in v0.15.0

func (*MockProvider) ValidateResourceConfig added in v0.15.0

type MockProvisioner added in v0.12.0

type MockProvisioner struct {
	sync.Mutex
	// Anything you want, in case you need to store extra data with the mock.
	Meta interface{}

	GetSchemaCalled   bool
	GetSchemaResponse provisioners.GetSchemaResponse

	ValidateProvisionerConfigCalled   bool
	ValidateProvisionerConfigRequest  provisioners.ValidateProvisionerConfigRequest
	ValidateProvisionerConfigResponse provisioners.ValidateProvisionerConfigResponse
	ValidateProvisionerConfigFn       func(provisioners.ValidateProvisionerConfigRequest) provisioners.ValidateProvisionerConfigResponse

	ProvisionResourceCalled   bool
	ProvisionResourceRequest  provisioners.ProvisionResourceRequest
	ProvisionResourceResponse provisioners.ProvisionResourceResponse
	ProvisionResourceFn       func(provisioners.ProvisionResourceRequest) provisioners.ProvisionResourceResponse

	StopCalled   bool
	StopResponse error
	StopFn       func() error

	CloseCalled   bool
	CloseResponse error
	CloseFn       func() error
}

MockProvisioner implements provisioners.Interface but mocks out all the calls for testing purposes.

func (*MockProvisioner) Close added in v0.12.0

func (p *MockProvisioner) Close() error

func (*MockProvisioner) GetSchema added in v0.12.0

func (*MockProvisioner) ProvisionResource added in v0.12.0

func (*MockProvisioner) Stop added in v0.12.0

func (p *MockProvisioner) Stop() error

func (*MockProvisioner) ValidateProvisionerConfig added in v0.12.0

type MockUIInput added in v0.3.0

type MockUIInput struct {
	InputCalled       bool
	InputOpts         *InputOpts
	InputReturnMap    map[string]string
	InputReturnString string
	InputReturnError  error
	InputFn           func(*InputOpts) (string, error)
}

MockUIInput is an implementation of UIInput that can be used for tests.

func (*MockUIInput) Input added in v0.3.0

func (i *MockUIInput) Input(ctx context.Context, opts *InputOpts) (string, error)

type MockUIOutput added in v0.3.0

type MockUIOutput struct {
	sync.Mutex
	OutputCalled  bool
	OutputMessage string
	OutputFn      func(string)
}

MockUIOutput is an implementation of UIOutput that can be used for tests.

func (*MockUIOutput) Output added in v0.3.0

func (o *MockUIOutput) Output(v string)

type ModuleExpansionTransformer added in v0.13.0

type ModuleExpansionTransformer struct {
	Config *configs.Config

	// Concrete allows injection of a wrapped module node by the graph builder
	// to alter the evaluation behavior.
	Concrete ConcreteModuleNodeFunc
	// contains filtered or unexported fields
}

ModuleExpansionTransformer is a GraphTransformer that adds graph nodes representing the possible expansion of each module call in the configuration, and ensures that any nodes representing objects declared within a module are dependent on the expansion node so that they will be visited only after the module expansion has been decided.

This transform must be applied only after all nodes representing objects that can be contained within modules have already been added.

func (*ModuleExpansionTransformer) Transform added in v0.13.0

func (t *ModuleExpansionTransformer) Transform(g *Graph) error

type ModuleVariableTransformer added in v0.7.8

type ModuleVariableTransformer struct {
	Config *configs.Config
}

ModuleVariableTransformer is a GraphTransformer that adds all the variables in the configuration to the graph.

Any "variable" block present in any non-root module is included here, even if a particular variable is not referenced from anywhere.

The transform will produce errors if a call to a module does not conform to the expected set of arguments, but this transformer is not in a good position to return errors and so the validate walk should include specific steps for validating module blocks, separate from this transform.

func (*ModuleVariableTransformer) Transform added in v0.7.8

func (t *ModuleVariableTransformer) Transform(g *Graph) error

type NilHook

type NilHook struct{}

NilHook is a Hook implementation that does nothing. It exists only to simplify implementing hooks. You can embed this into your Hook implementation and only implement the functions you are interested in.

func (*NilHook) PostApply

func (*NilHook) PostApply(addr addrs.AbsResourceInstance, gen states.Generation, newState cty.Value, err error) (HookAction, error)

func (*NilHook) PostDiff

func (*NilHook) PostDiff(addr addrs.AbsResourceInstance, gen states.Generation, action plans.Action, priorState, plannedNewState cty.Value) (HookAction, error)

func (*NilHook) PostImportState added in v0.7.0

func (*NilHook) PostImportState(addr addrs.AbsResourceInstance, imported []providers.ImportedResource) (HookAction, error)

func (*NilHook) PostProvisionInstance added in v0.12.0

func (*NilHook) PostProvisionInstance(addr addrs.AbsResourceInstance, state cty.Value) (HookAction, error)

func (*NilHook) PostProvisionInstanceStep added in v0.12.0

func (*NilHook) PostProvisionInstanceStep(addr addrs.AbsResourceInstance, typeName string, err error) (HookAction, error)

func (*NilHook) PostRefresh

func (*NilHook) PostRefresh(addr addrs.AbsResourceInstance, gen states.Generation, priorState cty.Value, newState cty.Value) (HookAction, error)

func (*NilHook) PostStateUpdate added in v0.4.0

func (*NilHook) PostStateUpdate(new *states.State) (HookAction, error)

func (*NilHook) PreApply

func (*NilHook) PreApply(addr addrs.AbsResourceInstance, gen states.Generation, action plans.Action, priorState, plannedNewState cty.Value) (HookAction, error)

func (*NilHook) PreDiff

func (*NilHook) PreDiff(addr addrs.AbsResourceInstance, gen states.Generation, priorState, proposedNewState cty.Value) (HookAction, error)

func (*NilHook) PreImportState added in v0.7.0

func (*NilHook) PreImportState(addr addrs.AbsResourceInstance, importID string) (HookAction, error)

func (*NilHook) PreProvisionInstance added in v0.12.0

func (*NilHook) PreProvisionInstance(addr addrs.AbsResourceInstance, state cty.Value) (HookAction, error)

func (*NilHook) PreProvisionInstanceStep added in v0.12.0

func (*NilHook) PreProvisionInstanceStep(addr addrs.AbsResourceInstance, typeName string) (HookAction, error)

func (*NilHook) PreRefresh

func (*NilHook) PreRefresh(addr addrs.AbsResourceInstance, gen states.Generation, priorState cty.Value) (HookAction, error)

func (*NilHook) ProvisionOutput added in v0.3.0

func (*NilHook) ProvisionOutput(addr addrs.AbsResourceInstance, typeName string, line string)

type NodeAbstractProvider added in v0.7.8

type NodeAbstractProvider struct {
	Addr addrs.AbsProviderConfig

	Config *configs.Provider
	Schema *configschema.Block
}

NodeAbstractProvider represents a provider that has no associated operations. It registers all the common interfaces across operations for providers.

func (*NodeAbstractProvider) AttachProvider added in v0.7.8

func (n *NodeAbstractProvider) AttachProvider(c *configs.Provider)

GraphNodeAttachProvider

func (*NodeAbstractProvider) AttachProviderConfigSchema added in v0.12.0

func (n *NodeAbstractProvider) AttachProviderConfigSchema(schema *configschema.Block)

GraphNodeAttachProviderConfigSchema impl.

func (*NodeAbstractProvider) DotNode added in v0.8.0

func (n *NodeAbstractProvider) DotNode(name string, opts *dag.DotOpts) *dag.DotNode

GraphNodeDotter impl.

func (*NodeAbstractProvider) ModulePath added in v0.13.0

func (n *NodeAbstractProvider) ModulePath() addrs.Module

GraphNodeModulePath

func (*NodeAbstractProvider) Name added in v0.7.8

func (n *NodeAbstractProvider) Name() string

func (*NodeAbstractProvider) Path added in v0.7.8

GraphNodeModuleInstance

func (*NodeAbstractProvider) ProviderAddr added in v0.12.0

func (n *NodeAbstractProvider) ProviderAddr() addrs.AbsProviderConfig

GraphNodeProvider

func (*NodeAbstractProvider) ProviderConfig added in v0.7.8

func (n *NodeAbstractProvider) ProviderConfig() *configs.Provider

GraphNodeProvider

func (*NodeAbstractProvider) References added in v0.7.8

func (n *NodeAbstractProvider) References() []*addrs.Reference

GraphNodeReferencer

type NodeAbstractResource added in v0.7.8

type NodeAbstractResource struct {
	Addr addrs.ConfigResource

	Schema        *configschema.Block // Schema for processing the configuration body
	SchemaVersion uint64              // Schema version of "Schema", as decided by the provider
	Config        *configs.Resource   // Config is the resource in the config

	// ProviderMetas is the provider_meta configs for the module this resource belongs to
	ProviderMetas map[addrs.Provider]*configs.ProviderMeta

	ProvisionerSchemas map[string]*configschema.Block

	// Set from GraphNodeTargetable
	Targets []addrs.Targetable

	// The address of the provider this resource will use
	ResolvedProvider addrs.AbsProviderConfig
	// contains filtered or unexported fields
}

NodeAbstractResource represents a resource that has no associated operations. It registers all the interfaces for a resource that common across multiple operation types.

func NewNodeAbstractResource added in v0.12.0

func NewNodeAbstractResource(addr addrs.ConfigResource) *NodeAbstractResource

NewNodeAbstractResource creates an abstract resource graph node for the given absolute resource address.

func (*NodeAbstractResource) AttachDataResourceDependsOn added in v0.15.0

func (n *NodeAbstractResource) AttachDataResourceDependsOn(deps []addrs.ConfigResource, force bool)

graphNodeAttachDataResourceDependsOn

func (*NodeAbstractResource) AttachProviderMetaConfigs added in v0.13.0

func (n *NodeAbstractResource) AttachProviderMetaConfigs(c map[addrs.Provider]*configs.ProviderMeta)

GraphNodeAttachProviderMetaConfigs impl

func (*NodeAbstractResource) AttachProvisionerSchema added in v0.12.0

func (n *NodeAbstractResource) AttachProvisionerSchema(name string, schema *configschema.Block)

GraphNodeProvisionerConsumer

func (*NodeAbstractResource) AttachResourceConfig added in v0.7.8

func (n *NodeAbstractResource) AttachResourceConfig(c *configs.Resource)

GraphNodeAttachResourceConfig

func (*NodeAbstractResource) AttachResourceSchema added in v0.12.0

func (n *NodeAbstractResource) AttachResourceSchema(schema *configschema.Block, version uint64)

GraphNodeAttachResourceSchema impl

func (*NodeAbstractResource) DependsOn added in v0.13.0

func (n *NodeAbstractResource) DependsOn() []*addrs.Reference

func (*NodeAbstractResource) DotNode added in v0.8.0

func (n *NodeAbstractResource) DotNode(name string, opts *dag.DotOpts) *dag.DotNode

GraphNodeDotter impl.

func (*NodeAbstractResource) ModulePath added in v0.13.0

func (n *NodeAbstractResource) ModulePath() addrs.Module

GraphNodeModulePath

func (*NodeAbstractResource) Name added in v0.7.8

func (n *NodeAbstractResource) Name() string

func (*NodeAbstractResource) ProvidedBy added in v0.7.8

func (n *NodeAbstractResource) ProvidedBy() (addrs.ProviderConfig, bool)

GraphNodeProviderConsumer

func (*NodeAbstractResource) Provider added in v0.13.0

func (n *NodeAbstractResource) Provider() addrs.Provider

GraphNodeProviderConsumer

func (*NodeAbstractResource) ProvisionedBy added in v0.7.8

func (n *NodeAbstractResource) ProvisionedBy() []string

GraphNodeProvisionerConsumer

func (*NodeAbstractResource) ReferenceableAddrs added in v0.12.0

func (n *NodeAbstractResource) ReferenceableAddrs() []addrs.Referenceable

GraphNodeReferenceable

func (*NodeAbstractResource) References added in v0.7.8

func (n *NodeAbstractResource) References() []*addrs.Reference

GraphNodeReferencer

func (*NodeAbstractResource) ResourceAddr added in v0.7.8

func (n *NodeAbstractResource) ResourceAddr() addrs.ConfigResource

GraphNodeResource

func (*NodeAbstractResource) SetProvider added in v0.11.0

func (n *NodeAbstractResource) SetProvider(p addrs.AbsProviderConfig)

func (*NodeAbstractResource) SetTargets added in v0.7.8

func (n *NodeAbstractResource) SetTargets(targets []addrs.Targetable)

GraphNodeTargetable

type NodeAbstractResourceInstance added in v0.12.0

type NodeAbstractResourceInstance struct {
	NodeAbstractResource
	Addr addrs.AbsResourceInstance

	Dependencies []addrs.ConfigResource
	// contains filtered or unexported fields
}

NodeAbstractResourceInstance represents a resource instance with no associated operations. It embeds NodeAbstractResource but additionally contains an instance key, used to identify one of potentially many instances that were created from a resource in configuration, e.g. using the "count" or "for_each" arguments.

func NewNodeAbstractResourceInstance added in v0.12.0

func NewNodeAbstractResourceInstance(addr addrs.AbsResourceInstance) *NodeAbstractResourceInstance

NewNodeAbstractResourceInstance creates an abstract resource instance graph node for the given absolute resource instance address.

func (*NodeAbstractResourceInstance) AttachResourceState added in v0.12.0

func (n *NodeAbstractResourceInstance) AttachResourceState(s *states.Resource)

GraphNodeAttachResourceState

func (*NodeAbstractResourceInstance) Name added in v0.12.0

func (*NodeAbstractResourceInstance) Path added in v0.13.0

func (*NodeAbstractResourceInstance) ProvidedBy added in v0.12.0

GraphNodeProviderConsumer

func (*NodeAbstractResourceInstance) Provider added in v0.13.0

GraphNodeProviderConsumer

func (*NodeAbstractResourceInstance) ReferenceableAddrs added in v0.12.0

func (n *NodeAbstractResourceInstance) ReferenceableAddrs() []addrs.Referenceable

GraphNodeReferenceable

func (*NodeAbstractResourceInstance) References added in v0.12.0

func (n *NodeAbstractResourceInstance) References() []*addrs.Reference

GraphNodeReferencer

func (*NodeAbstractResourceInstance) ResourceInstanceAddr added in v0.12.0

func (n *NodeAbstractResourceInstance) ResourceInstanceAddr() addrs.AbsResourceInstance

GraphNodeResourceInstance

func (*NodeAbstractResourceInstance) StateDependencies added in v0.12.14

func (n *NodeAbstractResourceInstance) StateDependencies() []addrs.ConfigResource

StateDependencies returns the dependencies saved in the state.

type NodeApplyableOutput added in v0.7.8

type NodeApplyableOutput struct {
	Addr   addrs.AbsOutputValue
	Config *configs.Output // Config is the output in the config
	// If this is being evaluated during apply, we may have a change recorded already
	Change *plans.OutputChangeSrc
}

NodeApplyableOutput represents an output that is "applyable": it is ready to be applied.

func (*NodeApplyableOutput) DotNode added in v0.12.0

func (n *NodeApplyableOutput) DotNode(name string, opts *dag.DotOpts) *dag.DotNode

dag.GraphNodeDotter impl.

func (*NodeApplyableOutput) Execute added in v0.14.0

func (n *NodeApplyableOutput) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeExecutable

func (*NodeApplyableOutput) ModulePath added in v0.13.0

func (n *NodeApplyableOutput) ModulePath() addrs.Module

GraphNodeModulePath

func (*NodeApplyableOutput) Name added in v0.7.8

func (n *NodeApplyableOutput) Name() string

func (*NodeApplyableOutput) Path added in v0.7.8

GraphNodeModuleInstance

func (*NodeApplyableOutput) ReferenceOutside added in v0.12.0

func (n *NodeApplyableOutput) ReferenceOutside() (selfPath, referencePath addrs.Module)

GraphNodeReferenceOutside implementation

func (*NodeApplyableOutput) ReferenceableAddrs added in v0.12.0

func (n *NodeApplyableOutput) ReferenceableAddrs() []addrs.Referenceable

GraphNodeReferenceable

func (*NodeApplyableOutput) References added in v0.7.8

func (n *NodeApplyableOutput) References() []*addrs.Reference

GraphNodeReferencer

type NodeApplyableProvider added in v0.7.8

type NodeApplyableProvider struct {
	*NodeAbstractProvider
}

NodeApplyableProvider represents a provider during an apply.

func (*NodeApplyableProvider) ConfigureProvider added in v0.14.0

func (n *NodeApplyableProvider) ConfigureProvider(ctx EvalContext, provider providers.Interface, verifyConfigIsKnown bool) (diags tfdiags.Diagnostics)

ConfigureProvider configures a provider that is already initialized and retrieved. If verifyConfigIsKnown is true, ConfigureProvider will return an error if the provider configVal is not wholly known and is meant only for use during import.

func (*NodeApplyableProvider) Execute added in v0.14.0

func (n *NodeApplyableProvider) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeExecutable

func (*NodeApplyableProvider) ValidateProvider added in v0.14.0

func (n *NodeApplyableProvider) ValidateProvider(ctx EvalContext, provider providers.Interface) (diags tfdiags.Diagnostics)

type NodeApplyableResource added in v0.7.8

type NodeApplyableResource struct {
	*NodeAbstractResource

	Addr addrs.AbsResource
}

NodeApplyableResource represents a resource that is "applyable": it may need to have its record in the state adjusted to match configuration.

Unlike in the plan walk, this resource node does not DynamicExpand. Instead, it should be inserted into the same graph as any instances of the nodes with dependency edges ensuring that the resource is evaluated before any of its instances, which will turn ensure that the whole-resource record in the state is suitably prepared to receive any updates to instances.

func (*NodeApplyableResource) Execute added in v0.14.0

func (n *NodeApplyableResource) Execute(ctx EvalContext, op walkOperation) tfdiags.Diagnostics

GraphNodeExecutable

func (*NodeApplyableResource) Path added in v0.13.0

func (*NodeApplyableResource) References added in v0.8.0

func (n *NodeApplyableResource) References() []*addrs.Reference

type NodeApplyableResourceInstance added in v0.12.0

type NodeApplyableResourceInstance struct {
	*NodeAbstractResourceInstance

	// If this node is forced to be CreateBeforeDestroy, we need to record that
	// in the state to.
	ForceCreateBeforeDestroy bool
	// contains filtered or unexported fields
}

NodeApplyableResourceInstance represents a resource instance that is "applyable": it is ready to be applied and is represented by a diff.

This node is for a specific instance of a resource. It will usually be accompanied in the graph by a NodeApplyableResource representing its containing resource, and should depend on that node to ensure that the state is properly prepared to receive changes to instances.

func (*NodeApplyableResourceInstance) AttachDependencies added in v0.12.14

func (n *NodeApplyableResourceInstance) AttachDependencies(deps []addrs.ConfigResource)

GraphNodeAttachDependencies

func (*NodeApplyableResourceInstance) CreateAddr added in v0.12.0

GraphNodeCreator

func (*NodeApplyableResourceInstance) CreateBeforeDestroy added in v0.13.0

func (n *NodeApplyableResourceInstance) CreateBeforeDestroy() bool

CreateBeforeDestroy returns this node's CreateBeforeDestroy status.

func (*NodeApplyableResourceInstance) Execute added in v0.14.0

func (n *NodeApplyableResourceInstance) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeExecutable

func (*NodeApplyableResourceInstance) ModifyCreateBeforeDestroy added in v0.13.0

func (n *NodeApplyableResourceInstance) ModifyCreateBeforeDestroy(v bool) error

func (*NodeApplyableResourceInstance) References added in v0.12.0

func (n *NodeApplyableResourceInstance) References() []*addrs.Reference

GraphNodeReferencer, overriding NodeAbstractResourceInstance

func (*NodeApplyableResourceInstance) SetPreallocatedDeposedKey added in v0.12.0

func (n *NodeApplyableResourceInstance) SetPreallocatedDeposedKey(key states.DeposedKey)

type NodeCountBoundary added in v0.7.8

type NodeCountBoundary struct {
	Config *configs.Config
}

NodeCountBoundary fixes up any transitions between "each modes" in objects saved in state, such as switching from NoEach to EachInt.

func (*NodeCountBoundary) Execute added in v0.14.0

func (n *NodeCountBoundary) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeExecutable

func (*NodeCountBoundary) Name added in v0.7.8

func (n *NodeCountBoundary) Name() string

type NodeDestroyDeposedResourceInstanceObject added in v0.12.0

type NodeDestroyDeposedResourceInstanceObject struct {
	*NodeAbstractResourceInstance
	DeposedKey states.DeposedKey
}

NodeDestroyDeposedResourceInstanceObject represents deposed resource instance objects during apply. Nodes of this type are inserted by DiffTransformer when the planned changeset contains "delete" changes for deposed instance objects, and its only supported operation is to destroy and then forget the associated object.

func (*NodeDestroyDeposedResourceInstanceObject) CreateBeforeDestroy added in v0.12.0

func (n *NodeDestroyDeposedResourceInstanceObject) CreateBeforeDestroy() bool

GraphNodeDestroyerCBD

func (*NodeDestroyDeposedResourceInstanceObject) DeposedInstanceObjectKey added in v0.12.0

func (n *NodeDestroyDeposedResourceInstanceObject) DeposedInstanceObjectKey() states.DeposedKey

func (*NodeDestroyDeposedResourceInstanceObject) DestroyAddr added in v0.12.0

GraphNodeDestroyer

func (*NodeDestroyDeposedResourceInstanceObject) Execute added in v0.14.0

func (n *NodeDestroyDeposedResourceInstanceObject) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeExecutable impl.

func (*NodeDestroyDeposedResourceInstanceObject) ModifyCreateBeforeDestroy added in v0.12.0

func (n *NodeDestroyDeposedResourceInstanceObject) ModifyCreateBeforeDestroy(v bool) error

GraphNodeDestroyerCBD

func (*NodeDestroyDeposedResourceInstanceObject) Name added in v0.12.0

func (*NodeDestroyDeposedResourceInstanceObject) ReferenceableAddrs added in v0.12.0

GraphNodeReferenceable implementation, overriding the one from NodeAbstractResourceInstance

func (*NodeDestroyDeposedResourceInstanceObject) References added in v0.12.0

GraphNodeReferencer implementation, overriding the one from NodeAbstractResourceInstance

type NodeDestroyResourceInstance added in v0.12.0

type NodeDestroyResourceInstance struct {
	*NodeAbstractResourceInstance

	// If DeposedKey is set to anything other than states.NotDeposed then
	// this node destroys a deposed object of the associated instance
	// rather than its current object.
	DeposedKey states.DeposedKey
}

NodeDestroyResourceInstance represents a resource instance that is to be destroyed.

func (*NodeDestroyResourceInstance) CreateBeforeDestroy added in v0.12.0

func (n *NodeDestroyResourceInstance) CreateBeforeDestroy() bool

GraphNodeDestroyerCBD

func (*NodeDestroyResourceInstance) DestroyAddr added in v0.12.0

GraphNodeDestroyer

func (*NodeDestroyResourceInstance) Execute added in v0.14.0

func (n *NodeDestroyResourceInstance) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeExecutable

func (*NodeDestroyResourceInstance) ModifyCreateBeforeDestroy added in v0.12.0

func (n *NodeDestroyResourceInstance) ModifyCreateBeforeDestroy(v bool) error

GraphNodeDestroyerCBD

func (*NodeDestroyResourceInstance) Name added in v0.12.0

func (*NodeDestroyResourceInstance) ProvidedBy added in v0.15.0

func (n *NodeDestroyResourceInstance) ProvidedBy() (addr addrs.ProviderConfig, exact bool)

func (*NodeDestroyResourceInstance) ReferenceableAddrs added in v0.12.0

func (n *NodeDestroyResourceInstance) ReferenceableAddrs() []addrs.Referenceable

GraphNodeReferenceable, overriding NodeAbstractResource

func (*NodeDestroyResourceInstance) References added in v0.12.0

func (n *NodeDestroyResourceInstance) References() []*addrs.Reference

GraphNodeReferencer, overriding NodeAbstractResource

type NodeDestroyableDataResourceInstance added in v0.12.0

type NodeDestroyableDataResourceInstance struct {
	*NodeAbstractResourceInstance
}

NodeDestroyableDataResourceInstance represents a resource that is "destroyable": it is ready to be destroyed.

func (*NodeDestroyableDataResourceInstance) Execute added in v0.14.0

func (n *NodeDestroyableDataResourceInstance) Execute(ctx EvalContext, op walkOperation) tfdiags.Diagnostics

GraphNodeExecutable

type NodeDestroyableOutput added in v0.11.4

type NodeDestroyableOutput struct {
	Addr   addrs.AbsOutputValue
	Config *configs.Output // Config is the output in the config
}

NodeDestroyableOutput represents an output that is "destroyable": its application will remove the output from the state.

func (*NodeDestroyableOutput) DotNode added in v0.12.0

func (n *NodeDestroyableOutput) DotNode(name string, opts *dag.DotOpts) *dag.DotNode

dag.GraphNodeDotter impl.

func (*NodeDestroyableOutput) Execute added in v0.14.0

func (n *NodeDestroyableOutput) Execute(ctx EvalContext, op walkOperation) tfdiags.Diagnostics

GraphNodeExecutable

func (*NodeDestroyableOutput) ModulePath added in v0.13.0

func (n *NodeDestroyableOutput) ModulePath() addrs.Module

GraphNodeModulePath

func (*NodeDestroyableOutput) Name added in v0.11.4

func (n *NodeDestroyableOutput) Name() string

type NodeEvalableProvider added in v0.12.0

type NodeEvalableProvider struct {
	*NodeAbstractProvider
}

NodeEvalableProvider represents a provider during an "eval" walk. This special provider node type just initializes a provider and fetches its schema, without configuring it or otherwise interacting with it.

func (*NodeEvalableProvider) Execute added in v0.14.0

func (n *NodeEvalableProvider) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeExecutable

type NodeLocal added in v0.10.3

type NodeLocal struct {
	Addr   addrs.AbsLocalValue
	Config *configs.Local
}

NodeLocal represents a named local value in a particular module.

Local value nodes only have one operation, common to all walk types: evaluate the result and place it in state.

func (*NodeLocal) DotNode added in v0.12.0

func (n *NodeLocal) DotNode(name string, opts *dag.DotOpts) *dag.DotNode

dag.GraphNodeDotter impl.

func (*NodeLocal) Execute added in v0.14.0

func (n *NodeLocal) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeExecutable NodeLocal.Execute is an Execute implementation that evaluates the expression for a local value and writes it into a transient part of the state.

func (*NodeLocal) ModulePath added in v0.13.0

func (n *NodeLocal) ModulePath() addrs.Module

GraphNodeModulePath

func (*NodeLocal) Name added in v0.10.3

func (n *NodeLocal) Name() string

func (*NodeLocal) Path added in v0.10.3

func (n *NodeLocal) Path() addrs.ModuleInstance

GraphNodeModuleInstance

func (*NodeLocal) ReferenceableAddrs added in v0.12.0

func (n *NodeLocal) ReferenceableAddrs() []addrs.Referenceable

GraphNodeReferenceable

func (*NodeLocal) References added in v0.10.3

func (n *NodeLocal) References() []*addrs.Reference

GraphNodeReferencer

type NodePlanDeposedResourceInstanceObject added in v0.12.0

type NodePlanDeposedResourceInstanceObject struct {
	*NodeAbstractResourceInstance
	DeposedKey states.DeposedKey
}

NodePlanDeposedResourceInstanceObject represents deposed resource instance objects during plan. These are distinct from the primary object for each resource instance since the only valid operation to do with them is to destroy them.

This node type is also used during the refresh walk to ensure that the record of a deposed object is up-to-date before we plan to destroy it.

func (*NodePlanDeposedResourceInstanceObject) DeposedInstanceObjectKey added in v0.12.0

func (n *NodePlanDeposedResourceInstanceObject) DeposedInstanceObjectKey() states.DeposedKey

func (*NodePlanDeposedResourceInstanceObject) Execute added in v0.14.0

func (n *NodePlanDeposedResourceInstanceObject) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeEvalable impl.

func (*NodePlanDeposedResourceInstanceObject) Name added in v0.12.0

func (*NodePlanDeposedResourceInstanceObject) ReferenceableAddrs added in v0.12.0

func (n *NodePlanDeposedResourceInstanceObject) ReferenceableAddrs() []addrs.Referenceable

GraphNodeReferenceable implementation, overriding the one from NodeAbstractResourceInstance

func (*NodePlanDeposedResourceInstanceObject) References added in v0.12.0

GraphNodeReferencer implementation, overriding the one from NodeAbstractResourceInstance

type NodePlanDestroyableResourceInstance added in v0.12.0

type NodePlanDestroyableResourceInstance struct {
	*NodeAbstractResourceInstance
	// contains filtered or unexported fields
}

NodePlanDestroyableResourceInstance represents a resource that is ready to be planned for destruction.

func (*NodePlanDestroyableResourceInstance) DestroyAddr added in v0.12.0

GraphNodeDestroyer

func (*NodePlanDestroyableResourceInstance) Execute added in v0.14.0

func (n *NodePlanDestroyableResourceInstance) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeEvalable

type NodePlannableResource added in v0.7.10

type NodePlannableResource struct {
	*NodeAbstractResource

	Addr addrs.AbsResource

	// ForceCreateBeforeDestroy might be set via our GraphNodeDestroyerCBD
	// during graph construction, if dependencies require us to force this
	// on regardless of what the configuration says.
	ForceCreateBeforeDestroy *bool
	// contains filtered or unexported fields
}

NodePlannableResource represents a resource that is "plannable": it is ready to be planned in order to create a diff.

func (*NodePlannableResource) CreateBeforeDestroy added in v0.12.0

func (n *NodePlannableResource) CreateBeforeDestroy() bool

GraphNodeDestroyerCBD

func (*NodePlannableResource) DynamicExpand added in v0.7.10

func (n *NodePlannableResource) DynamicExpand(ctx EvalContext) (*Graph, error)

GraphNodeDynamicExpandable

func (*NodePlannableResource) Execute added in v0.14.0

func (n *NodePlannableResource) Execute(ctx EvalContext, op walkOperation) tfdiags.Diagnostics

GraphNodeExecutable

func (*NodePlannableResource) ModifyCreateBeforeDestroy added in v0.12.0

func (n *NodePlannableResource) ModifyCreateBeforeDestroy(v bool) error

GraphNodeDestroyerCBD

func (*NodePlannableResource) Name added in v0.13.0

func (n *NodePlannableResource) Name() string

func (*NodePlannableResource) Path added in v0.13.0

type NodePlannableResourceInstance added in v0.7.10

type NodePlannableResourceInstance struct {
	*NodeAbstractResourceInstance
	ForceCreateBeforeDestroy bool
	// contains filtered or unexported fields
}

NodePlannableResourceInstance represents a _single_ resource instance that is plannable. This means this represents a single count index, for example.

func (*NodePlannableResourceInstance) Execute added in v0.14.0

func (n *NodePlannableResourceInstance) Execute(ctx EvalContext, op walkOperation) tfdiags.Diagnostics

GraphNodeEvalable

type NodePlannableResourceInstanceOrphan added in v0.12.0

type NodePlannableResourceInstanceOrphan struct {
	*NodeAbstractResourceInstance
	// contains filtered or unexported fields
}

NodePlannableResourceInstanceOrphan represents a resource that is "applyable": it is ready to be applied and is represented by a diff.

func (*NodePlannableResourceInstanceOrphan) Execute added in v0.14.0

func (n *NodePlannableResourceInstanceOrphan) Execute(ctx EvalContext, op walkOperation) tfdiags.Diagnostics

GraphNodeExecutable

func (*NodePlannableResourceInstanceOrphan) Name added in v0.12.0

func (*NodePlannableResourceInstanceOrphan) ProvidedBy added in v0.15.0

func (n *NodePlannableResourceInstanceOrphan) ProvidedBy() (addr addrs.ProviderConfig, exact bool)

type NodeRootVariable added in v0.7.8

type NodeRootVariable struct {
	Addr   addrs.InputVariable
	Config *configs.Variable
}

NodeRootVariable represents a root variable input.

func (*NodeRootVariable) DotNode added in v0.12.0

func (n *NodeRootVariable) DotNode(name string, opts *dag.DotOpts) *dag.DotNode

dag.GraphNodeDotter impl.

func (*NodeRootVariable) Execute added in v0.14.0

func (n *NodeRootVariable) Execute(ctx EvalContext, op walkOperation) tfdiags.Diagnostics

GraphNodeExecutable

func (*NodeRootVariable) ModulePath added in v0.13.0

func (n *NodeRootVariable) ModulePath() addrs.Module

func (*NodeRootVariable) Name added in v0.7.8

func (n *NodeRootVariable) Name() string

func (*NodeRootVariable) Path added in v0.12.0

GraphNodeModuleInstance

func (*NodeRootVariable) ReferenceableAddrs added in v0.12.0

func (n *NodeRootVariable) ReferenceableAddrs() []addrs.Referenceable

GraphNodeReferenceable

type NodeValidatableResource added in v0.9.0

type NodeValidatableResource struct {
	*NodeAbstractResource
}

NodeValidatableResource represents a resource that is used for validation only.

func (*NodeValidatableResource) Execute added in v0.14.0

func (n *NodeValidatableResource) Execute(ctx EvalContext, op walkOperation) (diags tfdiags.Diagnostics)

GraphNodeEvalable

func (*NodeValidatableResource) Path added in v0.13.0

type NullGraphWalker added in v0.4.0

type NullGraphWalker struct{}

NullGraphWalker is a GraphWalker implementation that does nothing. This can be embedded within other GraphWalker implementations for easily implementing all the required functions.

func (NullGraphWalker) EnterPath added in v0.5.0

func (NullGraphWalker) EvalContext added in v0.13.0

func (NullGraphWalker) EvalContext() EvalContext

func (NullGraphWalker) Execute added in v0.14.0

func (NullGraphWalker) ExitPath added in v0.5.0

type OrphanOutputTransformer added in v0.7.8

type OrphanOutputTransformer struct {
	Config *configs.Config // Root of config tree
	State  *states.State   // State is the root state
}

OrphanOutputTransformer finds the outputs that aren't present in the given config that are in the state and adds them to the graph for deletion.

func (*OrphanOutputTransformer) Transform added in v0.7.8

func (t *OrphanOutputTransformer) Transform(g *Graph) error

type OrphanResourceInstanceCountTransformer added in v0.13.0

type OrphanResourceInstanceCountTransformer struct {
	Concrete ConcreteResourceInstanceNodeFunc

	Addr          addrs.AbsResource           // Addr of the resource to look for orphans
	InstanceAddrs []addrs.AbsResourceInstance // Addresses that currently exist in config
	State         *states.State               // Full global state
}

OrphanResourceInstanceCountTransformer is a GraphTransformer that adds orphans for an expanded count to the graph. The determination of this depends on the count argument given.

Orphans are found by comparing the count to what is found in the state. This transform assumes that if an element in the state is within the count bounds given, that it is not an orphan.

func (*OrphanResourceInstanceCountTransformer) Transform added in v0.13.0

type OrphanResourceInstanceTransformer added in v0.12.0

type OrphanResourceInstanceTransformer struct {
	Concrete ConcreteResourceInstanceNodeFunc

	// State is the global state. We require the global state to
	// properly find module orphans at our path.
	State *states.State

	// Config is the root node in the configuration tree. We'll look up
	// the appropriate note in this tree using the path in each node.
	Config *configs.Config
}

OrphanResourceInstanceTransformer is a GraphTransformer that adds orphaned resource instances to the graph. An "orphan" is an instance that is present in the state but belongs to a resource that is no longer present in the configuration.

This is not the transformer that deals with "count orphans" (instances that are no longer covered by a resource's "count" or "for_each" setting); that's handled instead by OrphanResourceCountTransformer.

func (*OrphanResourceInstanceTransformer) Transform added in v0.12.0

type OutputTransformer added in v0.7.8

type OutputTransformer struct {
	Config  *configs.Config
	Changes *plans.Changes

	// if this is a planed destroy, root outputs are still in the configuration
	// so we need to record that we wish to remove them
	Destroy bool
}

OutputTransformer is a GraphTransformer that adds all the outputs in the configuration to the graph.

This is done for the apply graph builder even if dependent nodes aren't changing since there is no downside: the state will be available even if the dependent items aren't changing.

func (*OutputTransformer) Transform added in v0.7.8

func (t *OutputTransformer) Transform(g *Graph) error

type PlanGraphBuilder added in v0.7.10

type PlanGraphBuilder struct {
	// Config is the configuration tree to build a plan from.
	Config *configs.Config

	// State is the current state
	State *states.State

	// Components is a factory for the plug-in components (providers and
	// provisioners) available for use.
	Components contextComponentFactory

	// Schemas is the repository of schemas we will draw from to analyse
	// the configuration.
	Schemas *Schemas

	// Targets are resources to target
	Targets []addrs.Targetable

	// ForceReplace are resource instances where if we would normally have
	// generated a NoOp or Update action then we'll force generating a replace
	// action instead. Create and Delete actions are not affected.
	ForceReplace []addrs.AbsResourceInstance

	// Validate will do structural validation of the graph.
	Validate bool

	// CustomConcrete can be set to customize the node types created
	// for various parts of the plan. This is useful in order to customize
	// the plan behavior.
	CustomConcrete         bool
	ConcreteProvider       ConcreteProviderNodeFunc
	ConcreteResource       ConcreteResourceNodeFunc
	ConcreteResourceOrphan ConcreteResourceInstanceNodeFunc
	ConcreteModule         ConcreteModuleNodeFunc
	// contains filtered or unexported fields
}

PlanGraphBuilder implements GraphBuilder and is responsible for building a graph for planning (creating a Terraform Diff).

The primary difference between this graph and others:

  • Based on the config since it represents the target state

  • Ignores lifecycle options since no lifecycle events occur here. This simplifies the graph significantly since complex transforms such as create-before-destroy can be completely ignored.

func (*PlanGraphBuilder) Build added in v0.7.10

See GraphBuilder

func (*PlanGraphBuilder) Steps added in v0.7.10

func (b *PlanGraphBuilder) Steps() []GraphTransformer

See GraphBuilder

type PrefixUIInput added in v0.3.0

type PrefixUIInput struct {
	IdPrefix    string
	QueryPrefix string
	UIInput     UIInput
}

PrefixUIInput is an implementation of UIInput that prefixes the ID with a string, allowing queries to be namespaced.

func (*PrefixUIInput) Input added in v0.3.0

func (i *PrefixUIInput) Input(ctx context.Context, opts *InputOpts) (string, error)

type ProviderConfigTransformer added in v0.11.0

type ProviderConfigTransformer struct {
	Providers []string
	Concrete  ConcreteProviderNodeFunc

	// Config is the root node of the configuration tree to add providers from.
	Config *configs.Config
	// contains filtered or unexported fields
}

ProviderConfigTransformer adds all provider nodes from the configuration and attaches the configs.

func (*ProviderConfigTransformer) Transform added in v0.11.0

func (t *ProviderConfigTransformer) Transform(g *Graph) error

type ProviderSchema added in v0.10.8

type ProviderSchema struct {
	Provider      *configschema.Block
	ProviderMeta  *configschema.Block
	ResourceTypes map[string]*configschema.Block
	DataSources   map[string]*configschema.Block

	ResourceTypeSchemaVersions map[string]uint64
}

ProviderSchema represents the schema for a provider's own configuration and the configuration for some or all of its resources and data sources.

The completeness of this structure depends on how it was constructed. When constructed for a configuration, it will generally include only resource types and data sources used by that configuration.

func (*ProviderSchema) SchemaForResourceAddr added in v0.12.0

func (ps *ProviderSchema) SchemaForResourceAddr(addr addrs.Resource) (schema *configschema.Block, version uint64)

SchemaForResourceAddr attempts to find a schema for the mode and type from the given resource address. Returns nil if no such schema is available.

func (*ProviderSchema) SchemaForResourceType added in v0.12.0

func (ps *ProviderSchema) SchemaForResourceType(mode addrs.ResourceMode, typeName string) (schema *configschema.Block, version uint64)

SchemaForResourceType attempts to find a schema for the given mode and type. Returns nil if no such schema is available.

type ProviderTransformer added in v0.4.0

type ProviderTransformer struct {
	Config *configs.Config
}

ProviderTransformer is a GraphTransformer that maps resources to providers within the graph. This will error if there are any resources that don't map to proper resources.

func (*ProviderTransformer) Transform added in v0.4.0

func (t *ProviderTransformer) Transform(g *Graph) error

type ProvisionerUIOutput added in v0.3.0

type ProvisionerUIOutput struct {
	InstanceAddr    addrs.AbsResourceInstance
	ProvisionerType string
	Hooks           []Hook
}

ProvisionerUIOutput is an implementation of UIOutput that calls a hook for the output so that the hooks can handle it.

func (*ProvisionerUIOutput) Output added in v0.3.0

func (o *ProvisionerUIOutput) Output(msg string)

type PruneProviderTransformer added in v0.4.0

type PruneProviderTransformer struct{}

PruneProviderTransformer removes any providers that are not actually used by anything, and provider proxies. This avoids the provider being initialized and configured. This both saves resources but also avoids errors since configuration may imply initialization which may require auth.

func (*PruneProviderTransformer) Transform added in v0.4.0

func (t *PruneProviderTransformer) Transform(g *Graph) error

type ReferenceMap added in v0.7.8

type ReferenceMap map[string][]dag.Vertex

ReferenceMap is a structure that can be used to efficiently check for references on a graph, mapping internal reference keys (as produced by the mapKey method) to one or more vertices that are identified by each key.

func NewReferenceMap added in v0.7.8

func NewReferenceMap(vs []dag.Vertex) ReferenceMap

NewReferenceMap is used to create a new reference map for the given set of vertices.

func (ReferenceMap) References added in v0.7.8

func (m ReferenceMap) References(v dag.Vertex) []dag.Vertex

References returns the set of vertices that the given vertex refers to, and any referenced addresses that do not have corresponding vertices.

type ReferenceTransformer added in v0.7.8

type ReferenceTransformer struct{}

ReferenceTransformer is a GraphTransformer that connects all the nodes that reference each other in order to form the proper ordering.

func (*ReferenceTransformer) Transform added in v0.7.8

func (t *ReferenceTransformer) Transform(g *Graph) error

type RemovedModuleTransformer added in v0.11.0

type RemovedModuleTransformer struct {
	Config *configs.Config // root node in the config tree
	State  *states.State
}

RemovedModuleTransformer implements GraphTransformer to add nodes indicating when a module was removed from the configuration.

func (*RemovedModuleTransformer) Transform added in v0.11.0

func (t *RemovedModuleTransformer) Transform(g *Graph) error

type ResourceCountTransformer added in v0.4.0

type ResourceCountTransformer struct {
	Concrete ConcreteResourceInstanceNodeFunc
	Schema   *configschema.Block

	Addr          addrs.ConfigResource
	InstanceAddrs []addrs.AbsResourceInstance
}

ResourceCountTransformer is a GraphTransformer that expands the count out for a specific resource.

This assumes that the count is already interpolated.

func (*ResourceCountTransformer) Transform added in v0.4.0

func (t *ResourceCountTransformer) Transform(g *Graph) error

type RootTransformer added in v0.4.0

type RootTransformer struct{}

RootTransformer is a GraphTransformer that adds a root to the graph.

func (*RootTransformer) Transform added in v0.4.0

func (t *RootTransformer) Transform(g *Graph) error

type RootVariableTransformer added in v0.7.8

type RootVariableTransformer struct {
	Config *configs.Config
}

RootVariableTransformer is a GraphTransformer that adds all the root variables to the graph.

Root variables are currently no-ops but they must be added to the graph since downstream things that depend on them must be able to reach them.

func (*RootVariableTransformer) Transform added in v0.7.8

func (t *RootVariableTransformer) Transform(g *Graph) error

type Schemas added in v0.10.8

type Schemas struct {
	Providers    map[addrs.Provider]*ProviderSchema
	Provisioners map[string]*configschema.Block
}

Schemas is a container for various kinds of schema that Terraform needs during processing.

func LoadSchemas added in v0.12.0

func LoadSchemas(config *configs.Config, state *states.State, components contextComponentFactory) (*Schemas, error)

LoadSchemas searches the given configuration, state and plan (any of which may be nil) for constructs that have an associated schema, requests the necessary schemas from the given component factory (which must _not_ be nil), and returns a single object representing all of the necessary schemas.

If an error is returned, it may be a wrapped tfdiags.Diagnostics describing errors across multiple separate objects. Errors here will usually indicate either misbehavior on the part of one of the providers or of the provider protocol itself. When returned with errors, the returned schemas object is still valid but may be incomplete.

func (*Schemas) ProviderConfig added in v0.12.0

func (ss *Schemas) ProviderConfig(provider addrs.Provider) *configschema.Block

ProviderConfig returns the schema for the provider configuration of the given provider type, or nil if no such schema is available.

func (*Schemas) ProviderSchema added in v0.12.0

func (ss *Schemas) ProviderSchema(provider addrs.Provider) *ProviderSchema

ProviderSchema returns the entire ProviderSchema object that was produced by the plugin for the given provider, or nil if no such schema is available.

It's usually better to go use the more precise methods offered by type Schemas to handle this detail automatically.

func (*Schemas) ProvisionerConfig added in v0.12.0

func (ss *Schemas) ProvisionerConfig(name string) *configschema.Block

ProvisionerConfig returns the schema for the configuration of a given provisioner, or nil of no such schema is available.

func (*Schemas) ResourceTypeConfig added in v0.12.0

func (ss *Schemas) ResourceTypeConfig(provider addrs.Provider, resourceMode addrs.ResourceMode, resourceType string) (block *configschema.Block, schemaVersion uint64)

ResourceTypeConfig returns the schema for the configuration of a given resource type belonging to a given provider type, or nil of no such schema is available.

In many cases the provider type is inferrable from the resource type name, but this is not always true because users can override the provider for a resource using the "provider" meta-argument. Therefore it's important to always pass the correct provider name, even though it many cases it feels redundant.

type Semaphore added in v0.3.1

type Semaphore chan struct{}

Semaphore is a wrapper around a channel to provide utility methods to clarify that we are treating the channel as a semaphore

func NewSemaphore added in v0.3.1

func NewSemaphore(n int) Semaphore

NewSemaphore creates a semaphore that allows up to a given limit of simultaneous acquisitions

func (Semaphore) Acquire added in v0.3.1

func (s Semaphore) Acquire()

Acquire is used to acquire an available slot. Blocks until available.

func (Semaphore) Release added in v0.3.1

func (s Semaphore) Release()

Release is used to return a slot. Acquire must be called as a pre-condition.

func (Semaphore) TryAcquire added in v0.3.1

func (s Semaphore) TryAcquire() bool

TryAcquire is used to do a non-blocking acquire. Returns a bool indicating success

type StateTransformer added in v0.7.8

type StateTransformer struct {
	// ConcreteCurrent and ConcreteDeposed are used to specialize the abstract
	// resource instance nodes that this transformer will create.
	//
	// If either of these is nil, the objects of that type will be skipped and
	// not added to the graph at all. It doesn't make sense to use this
	// transformer without setting at least one of these, since that would
	// skip everything and thus be a no-op.
	ConcreteCurrent ConcreteResourceInstanceNodeFunc
	ConcreteDeposed ConcreteResourceInstanceDeposedNodeFunc

	State *states.State
}

StateTransformer is a GraphTransformer that adds the elements of the state to the graph.

This transform is used for example by the DestroyPlanGraphBuilder to ensure that only resources that are in the state are represented in the graph.

func (*StateTransformer) Transform added in v0.7.8

func (t *StateTransformer) Transform(g *Graph) error

type TargetsTransformer added in v0.4.0

type TargetsTransformer struct {
	// List of targeted resource names specified by the user
	Targets []addrs.Targetable
}

TargetsTransformer is a GraphTransformer that, when the user specifies a list of resources to target, limits the graph to only those resources and their dependencies.

func (*TargetsTransformer) Transform added in v0.4.0

func (t *TargetsTransformer) Transform(g *Graph) error

type TransitiveReductionTransformer added in v0.4.0

type TransitiveReductionTransformer struct{}

TransitiveReductionTransformer is a GraphTransformer that performs finds the transitive reduction of the graph. For a definition of transitive reduction, see Wikipedia.

func (*TransitiveReductionTransformer) Transform added in v0.4.0

func (t *TransitiveReductionTransformer) Transform(g *Graph) error

type UIInput added in v0.3.0

type UIInput interface {
	Input(context.Context, *InputOpts) (string, error)
}

UIInput is the interface that must be implemented to ask for input from this user. This should forward the request to wherever the user inputs things to ask for values.

type UIOutput added in v0.3.0

type UIOutput interface {
	Output(string)
}

UIOutput is the interface that must be implemented to output data to the end user.

type ValueSourceType added in v0.12.0

type ValueSourceType rune

ValueSourceType describes what broad category of source location provided a particular value.

const (
	// ValueFromUnknown is the zero value of ValueSourceType and is not valid.
	ValueFromUnknown ValueSourceType = 0

	// ValueFromConfig indicates that a value came from a .tf or .tf.json file,
	// e.g. the default value defined for a variable.
	ValueFromConfig ValueSourceType = 'C'

	// ValueFromAutoFile indicates that a value came from a "values file", like
	// a .tfvars file, that was implicitly loaded by naming convention.
	ValueFromAutoFile ValueSourceType = 'F'

	// ValueFromNamedFile indicates that a value came from a named "values file",
	// like a .tfvars file, that was passed explicitly on the command line (e.g.
	// -var-file=foo.tfvars).
	ValueFromNamedFile ValueSourceType = 'N'

	// ValueFromCLIArg indicates that the value was provided directly in
	// a CLI argument. The name of this argument is not recorded and so it must
	// be inferred from context.
	ValueFromCLIArg ValueSourceType = 'A'

	// ValueFromEnvVar indicates that the value was provided via an environment
	// variable. The name of the variable is not recorded and so it must be
	// inferred from context.
	ValueFromEnvVar ValueSourceType = 'E'

	// ValueFromInput indicates that the value was provided at an interactive
	// input prompt.
	ValueFromInput ValueSourceType = 'I'

	// ValueFromPlan indicates that the value was retrieved from a stored plan.
	ValueFromPlan ValueSourceType = 'P'

	// ValueFromCaller indicates that the value was explicitly overridden by
	// a caller to Context.SetVariable after the context was constructed.
	ValueFromCaller ValueSourceType = 'S'
)

func (ValueSourceType) GoString added in v0.12.0

func (v ValueSourceType) GoString() string

func (ValueSourceType) String added in v0.12.0

func (i ValueSourceType) String() string

type VertexTransformer added in v0.4.0

type VertexTransformer struct {
	Transforms []GraphVertexTransformer
}

VertexTransformer is a GraphTransformer that transforms vertices using the GraphVertexTransformers. The Transforms are run in sequential order. If a transform replaces a vertex then the next transform will see the new vertex.

func (*VertexTransformer) Transform added in v0.4.0

func (t *VertexTransformer) Transform(g *Graph) error

Notes

Bugs

  • we're not validating provider_meta blocks on EvalValidate right now because the ProviderAddr for the resource isn't available on the EvalValidate struct.

Source Files

Jump to

Keyboard shortcuts

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