| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590 | package uastimport (	"context"	"errors"	"fmt"	"io"	"io/ioutil"	"os"	"path"	"runtime"	"strings"	"sync"	"time"	"github.com/gogo/protobuf/proto"	"github.com/jeffail/tunny"	"gopkg.in/bblfsh/client-go.v2"	"gopkg.in/bblfsh/sdk.v1/protocol"	"gopkg.in/bblfsh/sdk.v1/uast"	"gopkg.in/src-d/go-git.v4"	"gopkg.in/src-d/go-git.v4/plumbing"	"gopkg.in/src-d/go-git.v4/plumbing/object"	"gopkg.in/src-d/go-git.v4/utils/merkletrie"	"gopkg.in/src-d/hercules.v6/internal/core"	"gopkg.in/src-d/hercules.v6/internal/pb"	items "gopkg.in/src-d/hercules.v6/internal/plumbing")// Extractor retrieves UASTs from Babelfish server which correspond to changed files in a commit.// It is a PipelineItem.type Extractor struct {	core.NoopMerger	Endpoint       string	Context        func() (context.Context, context.CancelFunc)	PoolSize       int	FailOnErrors   bool	ProcessedFiles map[string]int	clients []*bblfsh.Client	pool    *tunny.Pool}const (	// ConfigUASTEndpoint is the name of the configuration option (Extractor.Configure())	// which sets the Babelfish server address.	ConfigUASTEndpoint = "ConfigUASTEndpoint"	// ConfigUASTTimeout is the name of the configuration option (Extractor.Configure())	// which sets the maximum amount of time to wait for a Babelfish server response.	ConfigUASTTimeout = "ConfigUASTTimeout"	// ConfigUASTPoolSize is the name of the configuration option (Extractor.Configure())	// which sets the number of goroutines to run for UAST parse queries.	ConfigUASTPoolSize = "ConfigUASTPoolSize"	// ConfigUASTFailOnErrors is the name of the configuration option (Extractor.Configure())	// which enables early exit in case of any Babelfish UAST parsing errors.	ConfigUASTFailOnErrors = "ConfigUASTFailOnErrors"	// FeatureUast is the name of the Pipeline feature which activates all the items related to UAST.	FeatureUast = "uast"	// DependencyUasts is the name of the dependency provided by Extractor.	DependencyUasts = "uasts")type uastTask struct {	Lock   *sync.RWMutex	Dest   map[plumbing.Hash]*uast.Node	Name   string	Hash   plumbing.Hash	Data   []byte	Errors *[]error}type worker struct {	Client    *bblfsh.Client	Extractor *Extractor}// Process will synchronously perform a job and return the result.func (w worker) Process(data interface{}) interface{} {	return w.Extractor.extractTask(w.Client, data)}func (w worker) BlockUntilReady() {}func (w worker) Interrupt()       {}func (w worker) Terminate()       {}// Name of this PipelineItem. Uniquely identifies the type, used for mapping keys, etc.func (exr *Extractor) Name() string {	return "UAST"}// Provides returns the list of names of entities which are produced by this PipelineItem.// Each produced entity will be inserted into `deps` of dependent Consume()-s according// to this list. Also used by core.Registry to build the global map of providers.func (exr *Extractor) Provides() []string {	arr := [...]string{DependencyUasts}	return arr[:]}// Requires returns the list of names of entities which are needed by this PipelineItem.// Each requested entity will be inserted into `deps` of Consume(). In turn, those// entities are Provides() upstream.func (exr *Extractor) Requires() []string {	arr := [...]string{items.DependencyTreeChanges, items.DependencyBlobCache}	return arr[:]}// Features which must be enabled for this PipelineItem to be automatically inserted into the DAG.func (exr *Extractor) Features() []string {	arr := [...]string{FeatureUast}	return arr[:]}// ListConfigurationOptions returns the list of changeable public properties of this PipelineItem.func (exr *Extractor) ListConfigurationOptions() []core.ConfigurationOption {	options := [...]core.ConfigurationOption{{		Name:        ConfigUASTEndpoint,		Description: "How many days there are in a single band.",		Flag:        "bblfsh",		Type:        core.StringConfigurationOption,		Default:     "0.0.0.0:9432"}, {		Name:        ConfigUASTTimeout,		Description: "Babelfish's server timeout in seconds.",		Flag:        "bblfsh-timeout",		Type:        core.IntConfigurationOption,		Default:     20}, {		Name:        ConfigUASTPoolSize,		Description: "Number of goroutines to extract UASTs.",		Flag:        "bblfsh-pool-size",		Type:        core.IntConfigurationOption,		Default:     runtime.NumCPU() * 2}, {		Name:        ConfigUASTFailOnErrors,		Description: "Panic if there is a UAST extraction error.",		Flag:        "bblfsh-fail-on-error",		Type:        core.BoolConfigurationOption,		Default:     false},	}	return options[:]}// Configure sets the properties previously published by ListConfigurationOptions().func (exr *Extractor) Configure(facts map[string]interface{}) error {	if val, exists := facts[ConfigUASTEndpoint].(string); exists {		exr.Endpoint = val	}	if val, exists := facts[ConfigUASTTimeout].(int); exists {		exr.Context = func() (context.Context, context.CancelFunc) {			return context.WithTimeout(context.Background(),				time.Duration(val)*time.Second)		}	}	if val, exists := facts[ConfigUASTPoolSize].(int); exists {		exr.PoolSize = val	}	if val, exists := facts[ConfigUASTFailOnErrors].(bool); exists {		exr.FailOnErrors = val	}	return nil}// Initialize resets the temporary caches and prepares this PipelineItem for a series of Consume()// calls. The repository which is going to be analysed is supplied as an argument.func (exr *Extractor) Initialize(repository *git.Repository) error {	if exr.Context == nil {		exr.Context = func() (context.Context, context.CancelFunc) {			return context.Background(), nil		}	}	poolSize := exr.PoolSize	if poolSize == 0 {		poolSize = runtime.NumCPU()	}	exr.clients = make([]*bblfsh.Client, poolSize)	for i := 0; i < poolSize; i++ {		client, err := bblfsh.NewClient(exr.Endpoint)		if err != nil {			panic(err)		}		exr.clients[i] = client	}	if exr.pool != nil {		exr.pool.Close()	}	{		i := 0		exr.pool = tunny.New(poolSize, func() tunny.Worker {			w := worker{Client: exr.clients[i], Extractor: exr}			i++			return w		})	}	if exr.pool == nil {		panic("UAST goroutine pool was not created")	}	exr.ProcessedFiles = map[string]int{}	return nil}// Consume runs this PipelineItem on the next commit data.// `deps` contain all the results from upstream PipelineItem-s as requested by Requires().// Additionally, DependencyCommit is always present there and represents the analysed *object.Commit.// This function returns the mapping with analysis results. The keys must be the same as// in Provides(). If there was an error, nil is returned.func (exr *Extractor) Consume(deps map[string]interface{}) (map[string]interface{}, error) {	cache := deps[items.DependencyBlobCache].(map[plumbing.Hash]*items.CachedBlob)	treeDiffs := deps[items.DependencyTreeChanges].(object.Changes)	uasts := map[plumbing.Hash]*uast.Node{}	lock := sync.RWMutex{}	errs := make([]error, 0)	wg := sync.WaitGroup{}	submit := func(change *object.Change) {		exr.ProcessedFiles[change.To.Name]++		wg.Add(1)		go func(task interface{}) {			exr.pool.Process(task)			wg.Done()		}(uastTask{			Lock:   &lock,			Dest:   uasts,			Name:   change.To.Name,			Hash:   change.To.TreeEntry.Hash,			Data:   cache[change.To.TreeEntry.Hash].Data,			Errors: &errs,		})	}	for _, change := range treeDiffs {		action, err := change.Action()		if err != nil {			return nil, err		}		switch action {		case merkletrie.Insert:			submit(change)		case merkletrie.Delete:			continue		case merkletrie.Modify:			submit(change)		}	}	wg.Wait()	if len(errs) > 0 {		msgs := make([]string, len(errs))		for i, err := range errs {			msgs[i] = err.Error()		}		joined := strings.Join(msgs, "\n")		if exr.FailOnErrors {			return nil, errors.New(joined)		}		fmt.Fprintln(os.Stderr, joined)	}	return map[string]interface{}{DependencyUasts: uasts}, nil}// Fork clones this PipelineItem.func (exr *Extractor) Fork(n int) []core.PipelineItem {	return core.ForkSamePipelineItem(exr, n)}func (exr *Extractor) extractUAST(	client *bblfsh.Client, name string, data []byte) (*uast.Node, error) {	request := client.NewParseRequest()	request.Content(string(data))	request.Filename(name)	ctx, cancel := exr.Context()	if cancel != nil {		defer cancel()	}	response, err := request.DoWithContext(ctx)	if err != nil {		if strings.Contains("missing driver", err.Error()) {			return nil, nil		}		return nil, err	}	if response.Status != protocol.Ok {		return nil, errors.New(strings.Join(response.Errors, "\n"))	}	if err != nil {		return nil, err	}	return response.UAST, nil}func (exr *Extractor) extractTask(client *bblfsh.Client, data interface{}) interface{} {	task := data.(uastTask)	node, err := exr.extractUAST(client, task.Name, task.Data)	task.Lock.Lock()	defer task.Lock.Unlock()	if err != nil {		*task.Errors = append(*task.Errors,			fmt.Errorf("\nfile %s, blob %s: %v", task.Name, task.Hash.String(), err))		return nil	}	if node != nil {		task.Dest[task.Hash] = node	}	return nil}// Change is the type of the items in the list of changes which is provided by Changes.type Change struct {	Before *uast.Node	After  *uast.Node	Change *object.Change}const (	// DependencyUastChanges is the name of the dependency provided by Changes.	DependencyUastChanges = "changed_uasts")// Changes is a structured analog of TreeDiff: it provides UASTs for every logical change// in a commit. It is a PipelineItem.type Changes struct {	core.NoopMerger	cache map[plumbing.Hash]*uast.Node}// Name of this PipelineItem. Uniquely identifies the type, used for mapping keys, etc.func (uc *Changes) Name() string {	return "UASTChanges"}// Provides returns the list of names of entities which are produced by this PipelineItem.// Each produced entity will be inserted into `deps` of dependent Consume()-s according// to this list. Also used by core.Registry to build the global map of providers.func (uc *Changes) Provides() []string {	arr := [...]string{DependencyUastChanges}	return arr[:]}// Requires returns the list of names of entities which are needed by this PipelineItem.// Each requested entity will be inserted into `deps` of Consume(). In turn, those// entities are Provides() upstream.func (uc *Changes) Requires() []string {	arr := [...]string{DependencyUasts, items.DependencyTreeChanges}	return arr[:]}// Features which must be enabled for this PipelineItem to be automatically inserted into the DAG.func (uc *Changes) Features() []string {	arr := [...]string{FeatureUast}	return arr[:]}// ListConfigurationOptions returns the list of changeable public properties of this PipelineItem.func (uc *Changes) ListConfigurationOptions() []core.ConfigurationOption {	return []core.ConfigurationOption{}}// Configure sets the properties previously published by ListConfigurationOptions().func (uc *Changes) Configure(facts map[string]interface{}) error {	return nil}// Initialize resets the temporary caches and prepares this PipelineItem for a series of Consume()// calls. The repository which is going to be analysed is supplied as an argument.func (uc *Changes) Initialize(repository *git.Repository) error {	uc.cache = map[plumbing.Hash]*uast.Node{}	return nil}// Consume runs this PipelineItem on the next commit data.// `deps` contain all the results from upstream PipelineItem-s as requested by Requires().// Additionally, DependencyCommit is always present there and represents the analysed *object.Commit.// This function returns the mapping with analysis results. The keys must be the same as// in Provides(). If there was an error, nil is returned.func (uc *Changes) Consume(deps map[string]interface{}) (map[string]interface{}, error) {	uasts := deps[DependencyUasts].(map[plumbing.Hash]*uast.Node)	treeDiffs := deps[items.DependencyTreeChanges].(object.Changes)	commit := make([]Change, 0, len(treeDiffs))	for _, change := range treeDiffs {		action, err := change.Action()		if err != nil {			return nil, err		}		switch action {		case merkletrie.Insert:			hashTo := change.To.TreeEntry.Hash			uastTo := uasts[hashTo]			commit = append(commit, Change{Before: nil, After: uastTo, Change: change})			uc.cache[hashTo] = uastTo		case merkletrie.Delete:			hashFrom := change.From.TreeEntry.Hash			commit = append(commit, Change{Before: uc.cache[hashFrom], After: nil, Change: change})			delete(uc.cache, hashFrom)		case merkletrie.Modify:			hashFrom := change.From.TreeEntry.Hash			hashTo := change.To.TreeEntry.Hash			uastTo := uasts[hashTo]			commit = append(commit, Change{Before: uc.cache[hashFrom], After: uastTo, Change: change})			delete(uc.cache, hashFrom)			uc.cache[hashTo] = uastTo		}	}	return map[string]interface{}{DependencyUastChanges: commit}, nil}// Fork clones this PipelineItem.func (uc *Changes) Fork(n int) []core.PipelineItem {	ucs := make([]core.PipelineItem, n)	for i := 0; i < n; i++ {		clone := &Changes{			cache: map[plumbing.Hash]*uast.Node{},		}		for key, val := range uc.cache {			clone.cache[key] = val		}		ucs[i] = clone	}	return ucs}// ChangesSaver dumps changed files and corresponding UASTs for every commit.// it is a LeafPipelineItem.type ChangesSaver struct {	core.NoopMerger	core.OneShotMergeProcessor	// OutputPath points to the target directory with UASTs	OutputPath string	repository *git.Repository	result     [][]Change}const (	// ConfigUASTChangesSaverOutputPath is the name of the configuration option	// (ChangesSaver.Configure()) which sets the target directory where to save the files.	ConfigUASTChangesSaverOutputPath = "ChangesSaver.OutputPath")// Name of this PipelineItem. Uniquely identifies the type, used for mapping keys, etc.func (saver *ChangesSaver) Name() string {	return "UASTChangesSaver"}// Provides returns the list of names of entities which are produced by this PipelineItem.// Each produced entity will be inserted into `deps` of dependent Consume()-s according// to this list. Also used by core.Registry to build the global map of providers.func (saver *ChangesSaver) Provides() []string {	return []string{}}// Requires returns the list of names of entities which are needed by this PipelineItem.// Each requested entity will be inserted into `deps` of Consume(). In turn, those// entities are Provides() upstream.func (saver *ChangesSaver) Requires() []string {	arr := [...]string{DependencyUastChanges}	return arr[:]}// Features which must be enabled for this PipelineItem to be automatically inserted into the DAG.func (saver *ChangesSaver) Features() []string {	arr := [...]string{FeatureUast}	return arr[:]}// ListConfigurationOptions returns the list of changeable public properties of this PipelineItem.func (saver *ChangesSaver) ListConfigurationOptions() []core.ConfigurationOption {	options := [...]core.ConfigurationOption{{		Name:        ConfigUASTChangesSaverOutputPath,		Description: "The target directory where to store the changed UAST files.",		Flag:        "changed-uast-dir",		Type:        core.StringConfigurationOption,		Default:     "."},	}	return options[:]}// Flag for the command line switch which enables this analysis.func (saver *ChangesSaver) Flag() string {	return "dump-uast-changes"}// Description returns the text which explains what the analysis is doing.func (saver *ChangesSaver) Description() string {	return "Saves UASTs and file contents on disk for each commit."}// Configure sets the properties previously published by ListConfigurationOptions().func (saver *ChangesSaver) Configure(facts map[string]interface{}) error {	if val, exists := facts[ConfigUASTChangesSaverOutputPath]; exists {		saver.OutputPath = val.(string)	}	return nil}// Initialize resets the temporary caches and prepares this PipelineItem for a series of Consume()// calls. The repository which is going to be analysed is supplied as an argument.func (saver *ChangesSaver) Initialize(repository *git.Repository) error {	saver.repository = repository	saver.result = [][]Change{}	saver.OneShotMergeProcessor.Initialize()	return nil}// Consume runs this PipelineItem on the next commit data.// `deps` contain all the results from upstream PipelineItem-s as requested by Requires().// Additionally, DependencyCommit is always present there and represents the analysed *object.Commit.// This function returns the mapping with analysis results. The keys must be the same as// in Provides(). If there was an error, nil is returned.func (saver *ChangesSaver) Consume(deps map[string]interface{}) (map[string]interface{}, error) {	if !saver.ShouldConsumeCommit(deps) {		return nil, nil	}	changes := deps[DependencyUastChanges].([]Change)	saver.result = append(saver.result, changes)	return nil, nil}// Finalize returns the result of the analysis. Further Consume() calls are not expected.func (saver *ChangesSaver) Finalize() interface{} {	return saver.result}// Fork clones this PipelineItem.func (saver *ChangesSaver) Fork(n int) []core.PipelineItem {	return core.ForkSamePipelineItem(saver, n)}// Serialize converts the analysis result as returned by Finalize() to text or bytes.// The text format is YAML and the bytes format is Protocol Buffers.func (saver *ChangesSaver) Serialize(result interface{}, binary bool, writer io.Writer) error {	saverResult := result.([][]Change)	fileNames := saver.dumpFiles(saverResult)	if binary {		return saver.serializeBinary(fileNames, writer)	}	saver.serializeText(fileNames, writer)	return nil}func (saver *ChangesSaver) dumpFiles(result [][]Change) []*pb.UASTChange {	fileNames := []*pb.UASTChange{}	for i, changes := range result {		for j, change := range changes {			if change.Before == nil || change.After == nil {				continue			}			record := &pb.UASTChange{FileName: change.Change.To.Name}			bs, _ := change.Before.Marshal()			record.UastBefore = path.Join(saver.OutputPath, fmt.Sprintf(				"%d_%d_before_%s.pb", i, j, change.Change.From.TreeEntry.Hash.String()))			ioutil.WriteFile(record.UastBefore, bs, 0666)			blob, _ := saver.repository.BlobObject(change.Change.From.TreeEntry.Hash)			s, _ := (&object.File{Blob: *blob}).Contents()			record.SrcBefore = path.Join(saver.OutputPath, fmt.Sprintf(				"%d_%d_before_%s.src", i, j, change.Change.From.TreeEntry.Hash.String()))			ioutil.WriteFile(record.SrcBefore, []byte(s), 0666)			bs, _ = change.After.Marshal()			record.UastAfter = path.Join(saver.OutputPath, fmt.Sprintf(				"%d_%d_after_%s.pb", i, j, change.Change.To.TreeEntry.Hash.String()))			ioutil.WriteFile(record.UastAfter, bs, 0666)			blob, _ = saver.repository.BlobObject(change.Change.To.TreeEntry.Hash)			s, _ = (&object.File{Blob: *blob}).Contents()			record.SrcAfter = path.Join(saver.OutputPath, fmt.Sprintf(				"%d_%d_after_%s.src", i, j, change.Change.To.TreeEntry.Hash.String()))			ioutil.WriteFile(record.SrcAfter, []byte(s), 0666)			fileNames = append(fileNames, record)		}	}	return fileNames}func (saver *ChangesSaver) serializeText(result []*pb.UASTChange, writer io.Writer) {	for _, sc := range result {		kv := [...]string{			"file: " + sc.FileName,			"src0: " + sc.SrcBefore, "src1: " + sc.SrcAfter,			"uast0: " + sc.UastBefore, "uast1: " + sc.UastAfter,		}		fmt.Fprintf(writer, "  - {%s}\n", strings.Join(kv[:], ", "))	}}func (saver *ChangesSaver) serializeBinary(result []*pb.UASTChange, writer io.Writer) error {	message := pb.UASTChangesSaverResults{Changes: result}	serialized, err := proto.Marshal(&message)	if err != nil {		return err	}	_, err = writer.Write(serialized)	return err}func init() {	core.Registry.Register(&Extractor{})	core.Registry.Register(&Changes{})	core.Registry.Register(&ChangesSaver{})}
 |