Uploaded image for project: 'Kylin'
  1. Kylin
  2. KYLIN-2132

Unable to pull data from Kylin Cube ( learn_kylin cube ) to Excel or Power BI for Visualization and some dimensions are not showing up.

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Major
    • Resolution: Fixed
    • v1.5.4.1
    • v1.6.0
    • Driver - ODBC
    • None
    • HDP 2.4, Kylin: 1.5.4.1

    Description

      Hi all,

      I am unable to load data from KYLIN CUbe to Excel / power BI,
      i have installed all required drivers ( Microsoft Visual C++ 2012 Redistributable & KYLIN ODBC drivers ). i am able to connect successfully to KYLIN CUBE, but the data is not loading to excel / power BI because of below issue and also some dimensions are not showing up in Excel.

      Error Message:

      Value was either too large or too small for an Int32.

      Stack Trace:

      Microsoft.Mashup.Evaluator.Interface.ErrorException: Value was either too large or too small for an Int32. ---> Microsoft.Mashup.Evaluator.Interface.ErrorException: Value was either too large or too small for an Int32. ---> Microsoft.Mashup.Evaluator.Interface.ErrorException: Value was either too large or too small for an Int32. ---> Microsoft.Mashup.Evaluator.Interface.ErrorException: Value was either too large or too small for an Int32. ---> Microsoft.Mashup.Evaluator.Interface.ErrorException: Value was either too large or too small for an Int32. ---> System.OverflowException: Value was either too large or too small for an Int32. ---> System.OverflowException: Value was either too large or too small for an Int32.
      at System.Convert.ToInt32(Int64 value)
      at System.Int64.System.IConvertible.ToInt32(IFormatProvider provider)
      at System.Convert.ToInt32(Object value, IFormatProvider provider)
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcColumnInfoCollection.<EnsureInitialized>b__0(IOdbcConnection connection)
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcDataSource.<>c_DisplayClassf.<Connect>b_e(IOdbcConnection connection)
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcDataSource.<>c_DisplayClassc`1.<Connect>b_b()
      at Microsoft.Mashup.Engine1.Library.Common.DbExceptionHandler.RunWithRetryGuard[T](Int32 maxRetryAttempts, Func`1 action)
      at Microsoft.Mashup.Engine1.Library.Common.DbExceptionHandler.Invoke[T](Int32 maxRetry, Func`1 action)
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcDataSource.Connect[T](String currentCatalog, Func`2 func)
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcDataSource.Connect(Action`1 action)
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcColumnInfoCollection.EnsureInitialized()
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcQueryDomain.NewQuery(OdbcTableInfo table, List`1 fromItems)
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcTableValue.OdbcTableValueBuilder.CreateTableValue(OdbcTableInfo tableInfo)
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcHierarchicalNavigationTableValue.<>c_DisplayClass9.<CreateOdbcTable>b_8()
      at Microsoft.Mashup.Engine1.Runtime.DelayedValue.get_Value()
      at Microsoft.Mashup.Engine1.Library.Odbc.OdbcHierarchicalNavigationTableValue.OdbcTableLevelNavigationTableValue.<>c_DisplayClass1f.<NewLazyRow>b_1d(Int32 i)
      at Microsoft.Mashup.Engine1.Runtime.RecordValue.DemandRecordValue.get_Item(Int32 index)
      at Microsoft.Mashup.Engine1.Runtime.RecordValue.get_Item(String field)
      at Microsoft.Mashup.Engine1.Language.FieldAccessExpression.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.DebugExpression.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.FunctionInvocationExpression2.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.DebugExpression.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.RuntimeFunctionValue1.Invoke(Value arg0)
      at Microsoft.Mashup.Engine1.Language.RecordExpression.RuntimeRecordValue.Force(Int32 index)
      at Microsoft.Mashup.Engine1.Language.RecordExpression.RuntimeRecordValue.get_Item(Int32 index)
      at Microsoft.Mashup.Engine1.Runtime.RecordValue.get_Item(String field)
      at Microsoft.Mashup.Engine1.Language.FieldAccessExpression.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.RuntimeFunctionValue1.Invoke(Value arg0)
      at Microsoft.Mashup.Engine1.Language.RecordExpression.RuntimeRecordValue.Force(Int32 index)
      at Microsoft.Mashup.Engine1.Language.RecordExpression.RuntimeRecordValue.get_Item(Int32 index)
      at Microsoft.Mashup.Engine1.Runtime.RecordValue.get_Item(Value key)
      at Microsoft.Mashup.Engine1.Runtime.Library.Linker.BindFunctionValue.TypedInvoke(RecordValue environment, Value section, TextValue name)
      at Microsoft.Mashup.Engine1.Runtime.NativeFunctionValue3`4.Invoke(Value arg0, Value arg1, Value arg2)
      at Microsoft.Mashup.Engine1.Runtime.FunctionValue.Invoke(Value[] args)
      at Microsoft.Mashup.Engine1.Language.ExpressionInvocationExpression.Execute(MembersFrame0& frame)
      at Microsoft.Mashup.Engine1.Language.MembersFunctionValue0.Invoke()
      at Microsoft.Mashup.Engine1.Language.ListExpression.RuntimeListValue.Force(Int32 index)
      at Microsoft.Mashup.Engine1.Language.ListExpression.RuntimeListValue.get_Item(Int32 index)
      at Microsoft.Mashup.Engine1.Runtime.ListValue.get_Item(Value key)
      at Microsoft.Mashup.Engine1.Runtime.Library.List.ElementWithListCheckFunctionValue.Invoke(Value collection, Value key)
      at Microsoft.Mashup.Engine1.Language.FunctionInvocationExpression2.Execute(MembersFrame1& frame)
      at Microsoft.Mashup.Engine1.Language.MembersFunctionValue1.Invoke(Value arg0)
      at Microsoft.Mashup.Engine1.Language.RecordExpression.RuntimeRecordValue.Force(Int32 index)
      at Microsoft.Mashup.Engine1.Language.RecordExpression.RuntimeRecordValue.get_Item(Int32 index)
      at Microsoft.Mashup.Engine1.Runtime.RecordValue.get_Item(String field)
      at Microsoft.Mashup.Engine1.Language.FieldAccessExpression.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.FunctionInvocationExpression2.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.Expression.ExecuteCondition(Value frame)
      at Microsoft.Mashup.Engine1.Language.DebugExpression.ExecuteCondition(Value frame)
      at Microsoft.Mashup.Engine1.Language.IfExpression.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.DebugExpression.Execute(Value frame)
      at Microsoft.Mashup.Engine1.Language.RuntimeFunctionValue1.Invoke(Value arg0)
      at Microsoft.Mashup.Engine1.Language.RecordExpression.RuntimeRecordValue.Force(Int32 index)
      at Microsoft.Mashup.Engine1.Language.RecordExpression.RuntimeRecordValue.get_Item(Int32 index)
      at Microsoft.Mashup.Engine1.Runtime.RecordValue.get_Item(String field)
      at Microsoft.Mashup.Engine1.Language.FieldAccessExpression.Execute(MembersFrame0& frame)
      at Microsoft.Mashup.Engine1.Language.MembersFunctionValue0.Invoke()
      at Microsoft.Mashup.Engine1.Runtime.FunctionValue.Invoke(Value[] args)
      at Microsoft.Mashup.Engine1.Engine.Microsoft.Mashup.Engine.Interface.IEngine.Invoke(IValue function, IValue[] arguments)
      at Microsoft.Mashup.Evaluator.SimpleDocumentEvaluator.BeginGetResult(DocumentEvaluationParameters parameters, Action`1 callback)
      — End of inner exception stack trace —
      at Microsoft.Mashup.Evaluator.SimpleDocumentEvaluator.BeginGetResult(DocumentEvaluationParameters parameters, Action`1 callback)
      at Microsoft.Mashup.Evaluator.SimpleDocumentEvaluator.BeginGetResult(DocumentEvaluationParameters parameters, Action`1 callback)
      at Microsoft.Mashup.Evaluator.FirewallPartition.BeginGetResult[T](Action`1 callback)
      at Microsoft.Mashup.Evaluator.FirewallDocumentEvaluator.Evaluation`1.OnBufferComplete(Exception exception)
      at Microsoft.Mashup.Evaluator.Firewall.BufferNextPartition(List`1 partitionsToBuffer, Int32 nextPartition, Action`1 callback)
      at Microsoft.Mashup.Evaluator.Firewall.BeginBufferPartitions(Action`1 callback)
      at Microsoft.Mashup.Evaluator.FirewallDocumentEvaluator.BeginGetResultInternal[T](DocumentEvaluationParameters parameters, Action`1 callback)
      at Microsoft.Mashup.Evaluator.FirewallDocumentEvaluator.BeginGetResult(DocumentEvaluationParameters parameters, Action`1 callback)
      at Microsoft.Mashup.Evaluator.Interface.IDocumentEvaluatorExtensions.GetResult[T](IDocumentEvaluator`1 evaluator, DocumentEvaluationParameters parameters)
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.OnBeginGetResult[T](IMessageChannel channel, BeginGetResultMessage message, Action`1 action)
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.OnBeginGetPreviewValueSource(IMessageChannel channel, BeginGetPreviewValueSourceMessage message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.<>c_DisplayClassa`1.<AddHandler>b_8(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.ChannelMessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.Dispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.OnMessageWithUnknownChannel(IMessageChannel baseChannel, MessageWithUnknownChannel messageWithUnknownChannel)
      at Microsoft.Mashup.Evaluator.MessageHandlers.<>c_DisplayClassa`1.<AddHandler>b_8(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.ChannelMessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.Dispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.EvaluationHost.Run()
      at Microsoft.Mashup.Container.EvaluationContainerMain.Run(Object args)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass2.<CreateThreadStart>b_0(Object o)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass15.<CreateAction>b_14(Object o)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass2.<CreateThreadStart>b_1(Object o)
      at Microsoft.Mashup.Container.EvaluationContainerMain.SafeRun(String[] args)
      at Microsoft.Mashup.Container.EvaluationContainerMain.Main(String[] args)
      — End of inner exception stack trace —
      at Microsoft.Mashup.Evaluator.Interface.EvaluationResult2`1.get_Result()
      at Microsoft.Mashup.Evaluator.SimpleDocumentEvaluator.<>c_DisplayClass1.<BeginGetResult>b_0(EvaluationResult2`1 result)
      — End of inner exception stack trace —
      at Microsoft.Mashup.Evaluator.SimpleDocumentEvaluator.<>c_DisplayClass1.<BeginGetResult>b_0(EvaluationResult2`1 result)
      at Microsoft.Mashup.Evaluator.SimpleDocumentEvaluator.BeginGetResult(DocumentEvaluationParameters parameters, Action`1 callback)
      at Microsoft.Mashup.Evaluator.SimpleDocumentEvaluator.BeginGetResult(DocumentEvaluationParameters parameters, Action`1 callback)
      at Microsoft.Mashup.Evaluator.FirewallPartition.BeginGetResult[T](Action`1 callback)
      at Microsoft.Mashup.Evaluator.FirewallDocumentEvaluator.Evaluation`1.OnBufferComplete(Exception exception)
      at Microsoft.Mashup.Evaluator.Firewall.BufferNextPartition(List`1 partitionsToBuffer, Int32 nextPartition, Action`1 callback)
      at Microsoft.Mashup.Evaluator.Firewall.BeginBufferPartitions(Action`1 callback)
      at Microsoft.Mashup.Evaluator.FirewallDocumentEvaluator.BeginGetResultInternal[T](DocumentEvaluationParameters parameters, Action`1 callback)
      at Microsoft.Mashup.Evaluator.FirewallDocumentEvaluator.BeginGetResult(DocumentEvaluationParameters parameters, Action`1 callback)
      at Microsoft.Mashup.Evaluator.Interface.IDocumentEvaluatorExtensions.GetResult[T](IDocumentEvaluator`1 evaluator, DocumentEvaluationParameters parameters)
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.OnBeginGetResult[T](IMessageChannel channel, BeginGetResultMessage message, Action`1 action)
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.OnBeginGetPreviewValueSource(IMessageChannel channel, BeginGetPreviewValueSourceMessage message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.<>c_DisplayClassa`1.<AddHandler>b_8(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.ChannelMessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.Dispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.OnMessageWithUnknownChannel(IMessageChannel baseChannel, MessageWithUnknownChannel messageWithUnknownChannel)
      at Microsoft.Mashup.Evaluator.MessageHandlers.<>c_DisplayClassa`1.<AddHandler>b_8(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.ChannelMessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.Dispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.EvaluationHost.Run()
      at Microsoft.Mashup.Container.EvaluationContainerMain.Run(Object args)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass2.<CreateThreadStart>b_0(Object o)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass15.<CreateAction>b_14(Object o)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass2.<CreateThreadStart>b_1(Object o)
      at Microsoft.Mashup.Container.EvaluationContainerMain.SafeRun(String[] args)
      at Microsoft.Mashup.Container.EvaluationContainerMain.Main(String[] args)
      — End of inner exception stack trace —
      at Microsoft.Mashup.Evaluator.Interface.EvaluationResult2`1.get_Result()
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.<>c_DisplayClass15.<>cDisplayClass17.<OnBeginGetPreviewValueSource>b_14()
      at Microsoft.Mashup.Evaluator.RemotePreviewValueSource.<>c_DisplayClass5.<RunStub>b_3()
      at Microsoft.Mashup.Evaluator.EvaluationHost.ReportExceptions(IHostTrace trace, IEngineHost engineHost, IMessageChannel channel, Action action)
      — End of inner exception stack trace —
      at Microsoft.Mashup.Evaluator.EvaluationHost.<>c_DisplayClass7.<TryReportException>b_6()
      at Microsoft.Mashup.Common.SafeExceptions.IgnoreSafeExceptions(IHostTrace trace, Action action)
      at Microsoft.Mashup.Evaluator.EvaluationHost.TryReportException(IHostTrace trace, IEngineHost engineHost, IMessageChannel channel, Exception exception)
      at Microsoft.Mashup.Evaluator.EvaluationHost.ReportExceptions(IHostTrace trace, IEngineHost engineHost, IMessageChannel channel, Action action)
      at Microsoft.Mashup.Evaluator.RemotePreviewValueSource.RunStub(IEngineHost engineHost, IMessageChannel channel, Func`1 getPreviewValueSource)
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.<>c_DisplayClass15.<OnBeginGetPreviewValueSource>b_13(EvaluationResult2`1 result)
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.<>c_DisplayClass28`1.<OnBeginGetResult>b_25()
      at Microsoft.Mashup.Evaluator.EvaluationHost.ReportExceptions(IHostTrace trace, IEngineHost engineHost, IMessageChannel channel, Action action)
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.OnBeginGetResult[T](IMessageChannel channel, BeginGetResultMessage message, Action`1 action)
      at Microsoft.Mashup.Evaluator.RemoteDocumentEvaluator.Service.OnBeginGetPreviewValueSource(IMessageChannel channel, BeginGetPreviewValueSourceMessage message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.<>c_DisplayClassa`1.<AddHandler>b_8(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.ChannelMessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.Dispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.OnMessageWithUnknownChannel(IMessageChannel baseChannel, MessageWithUnknownChannel messageWithUnknownChannel)
      at Microsoft.Mashup.Evaluator.MessageHandlers.<>c_DisplayClassa`1.<AddHandler>b_8(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.ChannelMessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.Dispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.EvaluationHost.Run()
      at Microsoft.Mashup.Container.EvaluationContainerMain.Run(Object args)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass2.<CreateThreadStart>b_0(Object o)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass15.<CreateAction>b_14(Object o)
      at Microsoft.Mashup.Evaluator.SafeThread2.<>c_DisplayClass2.<CreateThreadStart>b_1(Object o)
      at Microsoft.Mashup.Container.EvaluationContainerMain.SafeRun(String[] args)
      at Microsoft.Mashup.Container.EvaluationContainerMain.Main(String[] args)
      — End of inner exception stack trace —
      at Microsoft.Mashup.Evaluator.EvaluationHost.OnException(IEngineHost engineHost, IMessageChannel channel, ExceptionMessage message)
      at Microsoft.Mashup.Evaluator.RemoteEvaluationContainerFactory.Container.OnException(IMessageChannel channel, ExceptionMessage message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.<>c_DisplayClassa`1.<AddHandler>b_8(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.Dispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.ChannelMessenger.ChannelMessageHandlers.TryDispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.MessageHandlers.Dispatch(IMessageChannel channel, Message message)
      at Microsoft.Mashup.Evaluator.Interface.IMessageChannelExtensions.WaitFor[T](IMessageChannel channel)
      at Microsoft.Mashup.Evaluator.RemotePreviewValueSource.PreviewValueSource.WaitFor(Func`1 condition, Boolean disposing)
      at Microsoft.Mashup.Evaluator.RemotePreviewValueSource.PreviewValueSource.get_Value()
      at Microsoft.Mashup.Evaluator.Interface.NotifyingPreviewValueSource.get_Value()
      at Microsoft.Mashup.Evaluator.Interface.NotifyingPreviewValueSource.get_Value()
      at Microsoft.Mashup.Host.Document.Preview.PreviewEvaluation.<>c_DisplayClassb.<StartEvaluation>b_8(EvaluationResult2`1 result)

      Invocation Stack Trace:

      at Microsoft.Mashup.Host.Document.ExceptionExtensions.GetCurrentInvocationStackTrace()
      at Microsoft.Mashup.Client.ClientShared.StackTraceInfo..ctor(String exceptionStackTrace, String invocationStackTrace)
      at Microsoft.Mashup.Client.ClientShared.FeedbackErrorInfo..ctor(String message, Nullable`1 errorCode, String requestId, Exception exception)
      at Microsoft.Mashup.Client.ClientShared.UnexpectedExceptionHandler.<>c_DisplayClass1.<HandleException>b_0()
      at Microsoft.Mashup.Host.Document.SynchronizationContextExtensions.SendAndMarshalExceptions(SynchronizationContext context, Action callback)
      at Microsoft.Mashup.Client.ClientShared.UnexpectedExceptionHandler.HandleException(Exception e)
      at Microsoft.Mashup.Client.ClientShared.Ux.HtmlForm.DelayedInitializationExceptionHandler.HandleException(Exception e)
      at Microsoft.Mashup.Client.ClientShared.Ux.HtmlForm.<>c_DisplayClass6.<OnAjaxException>b_5()
      at Microsoft.Mashup.Host.Document.ExceptionHandlerExtensions.HandleExceptions(IExceptionHandler exceptionHandler, Action action)
      at Microsoft.Mashup.Host.Document.SynchronizationContextExtensions.<>c_DisplayClassf.<Post>b_e(Object null)
      at System.RuntimeMethodHandle.InvokeMethod(Object target, Object[] arguments, Signature sig, Boolean constructor)
      at System.Reflection.RuntimeMethodInfo.UnsafeInvokeInternal(Object obj, Object[] parameters, Object[] arguments)
      at System.Delegate.DynamicInvokeImpl(Object[] args)
      at System.Windows.Forms.Control.InvokeMarshaledCallbackDo(ThreadMethodEntry tme)
      at System.Windows.Forms.Control.InvokeMarshaledCallbackHelper(Object obj)
      at System.Threading.ExecutionContext.RunInternal(ExecutionContext executionContext, ContextCallback callback, Object state, Boolean preserveSyncCtx)
      at System.Threading.ExecutionContext.Run(ExecutionContext executionContext, ContextCallback callback, Object state, Boolean preserveSyncCtx)
      at System.Threading.ExecutionContext.Run(ExecutionContext executionContext, ContextCallback callback, Object state)
      at System.Windows.Forms.Control.InvokeMarshaledCallback(ThreadMethodEntry tme)
      at System.Windows.Forms.Control.InvokeMarshaledCallbacks()
      at System.Windows.Forms.Control.WndProc(Message& m)
      at System.Windows.Forms.Control.ControlNativeWindow.OnMessage(Message& m)
      at System.Windows.Forms.Control.ControlNativeWindow.WndProc(Message& m)
      at System.Windows.Forms.NativeWindow.Callback(IntPtr hWnd, Int32 msg, IntPtr wparam, IntPtr lparam)
      at System.Windows.Forms.UnsafeNativeMethods.DispatchMessageW(MSG& msg)
      at System.Windows.Forms.Application.ThreadContext.LocalModalMessageLoop(Form form)
      at System.Windows.Forms.Application.ThreadContext.RunMessageLoopInner(Int32 reason, ApplicationContext context)
      at System.Windows.Forms.Application.ThreadContext.RunMessageLoop(Int32 reason, ApplicationContext context)
      at System.Windows.Forms.Application.RunDialog(Form form)
      at System.Windows.Forms.Form.ShowDialog(IWin32Window owner)
      at Microsoft.Mashup.Client.ClientShared.WindowManager.ShowDialog[T](T form, IWin32Window owner)
      at Microsoft.Mashup.Client.ClientShared.Ux.HtmlForm.ShowDialog(IWin32Window owner)
      at Microsoft.Mashup.Client.ClientShared.Ux.FloatingDialog.NavigatorFloatingDialog.ShowEditLoadTo(IWin32Window owner, WindowsHost windowsHost, Query query, ITelemetryService telemetryService)
      at Microsoft.Mashup.Client.Excel.ExcelDataImporter.ShowNavigator(Query query)
      at Microsoft.Mashup.Client.ClientShared.DataImporter.ShowNavigatorOnSourceQuery(Query query, IEnumerable`1& importedQueries)
      at Microsoft.Mashup.Client.ClientShared.DataImporter.ImportNavigationSource(Query query)
      at Microsoft.Mashup.Client.ClientShared.DataImporter.OnGetPreviewResult(PreviewResult preview, Query query, String sourceID, String formulaTitle, Nullable`1 explicitImportDestination, Boolean isNewQuery, Boolean isFromEditor)
      at Microsoft.Mashup.Client.ClientShared.DataImporter.<>c_DisplayClass1d.<OnQuerySettingsResolved>b_1a()
      at Microsoft.Mashup.Host.Document.ExceptionHandlerExtensions.HandleExceptions(IExceptionHandler exceptionHandler, Action action)
      at Microsoft.Mashup.Host.Document.SynchronizationContextExtensions.<>c_DisplayClassf.<Post>b_e(Object null)
      at System.RuntimeMethodHandle.InvokeMethod(Object target, Object[] arguments, Signature sig, Boolean constructor)
      at System.Reflection.RuntimeMethodInfo.UnsafeInvokeInternal(Object obj, Object[] parameters, Object[] arguments)
      at System.Delegate.DynamicInvokeImpl(Object[] args)
      at System.Windows.Forms.Control.InvokeMarshaledCallbackDo(ThreadMethodEntry tme)
      at System.Windows.Forms.Control.InvokeMarshaledCallbackHelper(Object obj)
      at System.Threading.ExecutionContext.RunInternal(ExecutionContext executionContext, ContextCallback callback, Object state, Boolean preserveSyncCtx)
      at System.Threading.ExecutionContext.Run(ExecutionContext executionContext, ContextCallback callback, Object state, Boolean preserveSyncCtx)
      at System.Threading.ExecutionContext.Run(ExecutionContext executionContext, ContextCallback callback, Object state)
      at System.Windows.Forms.Control.InvokeMarshaledCallback(ThreadMethodEntry tme)
      at System.Windows.Forms.Control.InvokeMarshaledCallbacks()
      at System.Windows.Forms.Control.WndProc(Message& m)
      at System.Windows.Forms.Control.ControlNativeWindow.OnMessage(Message& m)
      at System.Windows.Forms.Control.ControlNativeWindow.WndProc(Message& m)
      at System.Windows.Forms.NativeWindow.Callback(IntPtr hWnd, Int32 msg, IntPtr wparam, IntPtr lparam)

      Attachments

        1. KYLIN-2132.patch
          2 kB
          Yifan Zhang

        Issue Links

          Activity

            People

              event Yifan Zhang
              Bhanuprakash Bhanuprakash
              Votes:
              0 Vote for this issue
              Watchers:
              4 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: